2025.03.05 21:06:59.932277 [ 727 ] {} Context: Server was built with sanitizer. It will work slowly. 2025.03.05 21:06:59.945407 [ 727 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.03.05 21:06:59.945799 [ 727 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.03.05 21:06:59.946115 [ 727 ] {} Application: Integrity check of the executable skipped because the reference checksum could not be read. 2025.03.05 21:07:00.043603 [ 727 ] {} CloudPlacementInfo: Placement info has not been loaded 2025.03.05 21:07:00.101884 [ 727 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.03.05 21:07:00.102084 [ 727 ] {} KeeperLogStore: Removing all changelogs 2025.03.05 21:07:00.102490 [ 727 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.03.05 21:07:00.103418 [ 727 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.03.05 21:07:00.103430 [ 727 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.03.05 21:07:00.153825 [ 1306 ] {} RaftInstance: Election timeout, initiate leader election 2025.03.05 21:07:00.172025 [ 727 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.03.05 21:07:00.172047 [ 727 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.03.05 21:07:00.210537 [ 727 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.03.05 21:07:53.884961 [ 1480 ] {} ZooKeeperClient: Code: 33. DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000187cb1aa 5. ./src/Common/transformEndianness.h:18: void Coordination::ZooKeeper::read(int&) @ 0x000000003443f756 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:808: Coordination::ZooKeeper::receiveEvent() @ 0x0000000034430939 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000003442f85b 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003443c8a6 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:07:53.894357 [ 1469 ] {} ZooKeeperClient: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket (127.0.0.1:55956 -> 127.0.0.1:9181). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:709: Coordination::ZooKeeper::sendThread() @ 0x000000003442d712 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_0>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003443c3c6 8. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 10. ? @ 0x00007fe1df9bbac3 11. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:07:53.907175 [ 1480 ] {} ZooKeeperClient: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1040: Coordination::ZooKeeper::finalize(bool, bool, String const&) @ 0x000000003441c806 7. ./contrib/llvm-project/libcxx/include/string:1499: Coordination::ZooKeeper::receiveThread() @ 0x00000000344304a7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003443c8a6 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:07:54.883216 [ 1580 ] {338b219b-9dcd-4b69-9ae2-c525a29dac6d} executeQuery: Code: 370. DB::Exception: Data type Nullable(Nothing) of column 'x' cannot be used in tables. (DATA_TYPE_CANNOT_BE_USED_IN_TABLES) (version 24.3.12.76.altinitystable) (from [::1]:36624) (comment: 03243_check_for_nullable_nothing_in_alter.sql) (in query: alter table src modify column x Nullable(Nothing);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Storages/StorageFactory.cpp:0: DB::checkAllTypesAreAllowedInTable(DB::NamesAndTypesList const&) @ 0x00000000321d4621 5. ./contrib/llvm-project/libcxx/include/list:724: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032087894 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:54.883390 [ 1580 ] {338b219b-9dcd-4b69-9ae2-c525a29dac6d} TCPHandler: Code: 370. DB::Exception: Data type Nullable(Nothing) of column 'x' cannot be used in tables. (DATA_TYPE_CANNOT_BE_USED_IN_TABLES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Storages/StorageFactory.cpp:0: DB::checkAllTypesAreAllowedInTable(DB::NamesAndTypesList const&) @ 0x00000000321d4621 5. ./contrib/llvm-project/libcxx/include/list:724: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032087894 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:54.906167 [ 1577 ] {bae3a639-4009-4e1d-91c8-fcf416989029} executeQuery: Code: 475. DB::Exception: Sort FILL TO expression must be constant with numeric type. Actual '2024-02-17'. In scope SELECT * FROM users ORDER BY date ASC WITH FILL TO '2024-02-17' STEP toIntervalHour(1). (INVALID_WITH_FILL_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:36608) (comment: 03248_with_fill_string_crash.sql) (in query: SELECT * FROM users ORDER BY date WITH FILL TO '2024-02-17' STEP toIntervalHour(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308976b0 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003087303b 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 11. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:54.906330 [ 1577 ] {bae3a639-4009-4e1d-91c8-fcf416989029} TCPHandler: Code: 475. DB::Exception: Sort FILL TO expression must be constant with numeric type. Actual '2024-02-17'. In scope SELECT * FROM users ORDER BY date ASC WITH FILL TO '2024-02-17' STEP toIntervalHour(1). (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308976b0 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003087303b 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 11. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:54.970519 [ 1580 ] {ff145f27-0b9b-4573-9787-f5b737ca178f} executeQuery: Code: 370. DB::Exception: Data type Nullable(Nothing) of column 'x' cannot be used in tables. (DATA_TYPE_CANNOT_BE_USED_IN_TABLES) (version 24.3.12.76.altinitystable) (from [::1]:36624) (comment: 03243_check_for_nullable_nothing_in_alter.sql) (in query: alter table v modify query select NULL as x from src;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Storages/StorageFactory.cpp:0: DB::checkAllTypesAreAllowedInTable(DB::NamesAndTypesList const&) @ 0x00000000321d4621 5. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000322ec5bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795294 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:54.970884 [ 1580 ] {ff145f27-0b9b-4573-9787-f5b737ca178f} TCPHandler: Code: 370. DB::Exception: Data type Nullable(Nothing) of column 'x' cannot be used in tables. (DATA_TYPE_CANNOT_BE_USED_IN_TABLES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Storages/StorageFactory.cpp:0: DB::checkAllTypesAreAllowedInTable(DB::NamesAndTypesList const&) @ 0x00000000321d4621 5. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000322ec5bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795294 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:55.208256 [ 1655 ] {29468bab-928c-4518-834d-48a195afcb56} executeQuery: Code: 701. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. (CLUSTER_DOESNT_EXIST) (version 24.3.12.76.altinitystable) (from [::1]:36666) (comment: 03215_analyzer_replace_with_dummy_tables.sql) (in query: SELECT 1 FROM ( SELECT number IN ( SELECT number FROM view( SELECT number FROM numbers(1) ) ) FROM t ) SETTINGS allow_experimental_parallel_reading_from_replicas = 1, max_parallel_replicas = 2, allow_experimental_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:377: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>) @ 0x00000000318f3306 5. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:0: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x00000000310419c5 6. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100c44c 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:55.208474 [ 1655 ] {29468bab-928c-4518-834d-48a195afcb56} TCPHandler: Code: 701. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. (CLUSTER_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:377: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>) @ 0x00000000318f3306 5. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:0: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x00000000310419c5 6. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100c44c 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:55.277096 [ 1580 ] {59e65923-8fc4-443e-8e46-04ab540a48c9} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 1000000)). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:36660) (comment: 03217_json_merge_patch_stack_overflow.sql) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 1000000));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001d8152fb 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001d8134ef 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d8122ea 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:07:55.277280 [ 1580 ] {59e65923-8fc4-443e-8e46-04ab540a48c9} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 1000000)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001d8152fb 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001d8134ef 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d8122ea 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:07:55.287969 [ 1580 ] {6480baf3-0feb-4b5f-bba1-4f8eb015f978} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 100000)). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:36660) (comment: 03217_json_merge_patch_stack_overflow.sql) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 100000));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001d8152fb 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001d8134ef 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d8122ea 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:07:55.288144 [ 1580 ] {6480baf3-0feb-4b5f-bba1-4f8eb015f978} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 100000)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001d8152fb 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001d8134ef 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d8122ea 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:07:55.290597 [ 1580 ] {394b0780-dd46-4ea0-b61c-1af7a4151cbd} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 10000)). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:36660) (comment: 03217_json_merge_patch_stack_overflow.sql) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 10000));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001d8152fb 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001d8134ef 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d8122ea 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:07:55.290775 [ 1580 ] {394b0780-dd46-4ea0-b61c-1af7a4151cbd} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 10000)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001d8152fb 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001d8134ef 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d8122ea 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:07:55.292296 [ 1580 ] {77c01a51-55ff-4701-acd2-53f274d6269b} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 1000)). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:36660) (comment: 03217_json_merge_patch_stack_overflow.sql) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 1000));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001d8152fb 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001d8134ef 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d8122ea 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:07:55.292438 [ 1580 ] {77c01a51-55ff-4701-acd2-53f274d6269b} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 1000)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001d8152fb 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001d8134ef 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d8122ea 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:07:55.293878 [ 1580 ] {dde249fd-d4a4-44d9-91bd-3fb28c1da903} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 100)). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:36660) (comment: 03217_json_merge_patch_stack_overflow.sql) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 100));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001d8152fb 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001d8134ef 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d8122ea 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:07:55.293985 [ 1580 ] {dde249fd-d4a4-44d9-91bd-3fb28c1da903} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 100)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001d8152fb 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001d8134ef 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d8122ea 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:07:55.295609 [ 1580 ] {76a277ac-da72-4637-bfe1-45d84e1ec3a0} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 10)). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:36660) (comment: 03217_json_merge_patch_stack_overflow.sql) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 10));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001d8152fb 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001d8134ef 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d8122ea 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:07:55.295717 [ 1580 ] {76a277ac-da72-4637-bfe1-45d84e1ec3a0} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 10)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001d8152fb 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001d8134ef 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d8122ea 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:07:55.297210 [ 1580 ] {55c23d27-ca94-4884-88bd-1a8977943347} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 1)). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:36660) (comment: 03217_json_merge_patch_stack_overflow.sql) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001d8152fb 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001d8134ef 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d8122ea 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:07:55.297322 [ 1580 ] {55c23d27-ca94-4884-88bd-1a8977943347} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 1)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001d8152fb 4. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001d8134ef 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d8122ea 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:07:55.797930 [ 1658 ] {6f976b47-47d9-4f40-9c83-b9a416015f81} executeQuery: Code: 215. DB::Exception: Column mn is not under aggregate function and not in GROUP BY keys. In query SELECT n, number + 5 AS inter FROM (SELECT toFloat32(number % 10) AS n, number, number * 2 AS mn FROM numbers(10) WHERE (number % 3) = 1) GROUP BY n, inter ORDER BY n ASC WITH FILL FROM 0 TO 5.51 STEP 0.5 INTERPOLATE ( inter AS mn * 2 ). (NOT_AN_AGGREGATE) (version 24.3.12.76.altinitystable) (from [::1]:36806) (comment: 03155_analyzer_interpolate.sql) (in query: SELECT n, number+5 AS inter FROM ( -- { serverError NOT_AN_AGGREGATE } SELECT toFloat32(number % 10) AS n, number, number*2 AS mn FROM numbers(10) WHERE number % 3 = 1 ) GROUP BY n, inter ORDER BY n WITH FILL FROM 0 TO 5.51 STEP 0.5 INTERPOLATE (inter AS mn * 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003093e66a 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003093db02 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003093db02 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003093db02 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003093db02 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:272: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093c8ff 10. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:55.818398 [ 1658 ] {6f976b47-47d9-4f40-9c83-b9a416015f81} TCPHandler: Code: 215. DB::Exception: Column mn is not under aggregate function and not in GROUP BY keys. In query SELECT n, number + 5 AS inter FROM (SELECT toFloat32(number % 10) AS n, number, number * 2 AS mn FROM numbers(10) WHERE (number % 3) = 1) GROUP BY n, inter ORDER BY n ASC WITH FILL FROM 0 TO 5.51 STEP 0.5 INTERPOLATE ( inter AS mn * 2 ). (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003093e66a 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003093db02 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003093db02 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003093db02 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003093db02 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:272: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093c8ff 10. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:55.818398 [ 1579 ] {79528fc3-ca3a-4421-bbf4-de525c089d22} executeQuery: Code: 80. DB::Exception: Cannot CREATE a table AS test_foirosxh.mv_from_base_to_target, it is a Materialized View without storage. Use "AS `test_foirosxh.target_table`" instead. (INCORRECT_QUERY) (version 24.3.12.76.altinitystable) (from [::1]:36796) (comment: 03161_create_table_as_mv.sql) (in query: CREATE TABLE other_table_2 AS mv_from_base_to_target;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, DB::QualifiedTableName&&) @ 0x00000000307d827b 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:982: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000307bade7 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b4cdf 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:55.818622 [ 1579 ] {79528fc3-ca3a-4421-bbf4-de525c089d22} TCPHandler: Code: 80. DB::Exception: Cannot CREATE a table AS test_foirosxh.mv_from_base_to_target, it is a Materialized View without storage. Use "AS `test_foirosxh.target_table`" instead. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, DB::QualifiedTableName&&) @ 0x00000000307d827b 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:982: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000307bade7 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b4cdf 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:55.994902 [ 1655 ] {805e1727-167c-40f3-877c-a33544ed1047} executeQuery: Code: 36. DB::Exception: Window 'w' is already defined. In scope SELECT count(*) OVER w FROM users WINDOW w AS (ORDER BY uid ASC), w AS (ORDER BY name ASC). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:36856) (comment: 03149_analyzer_window_redefinition.sql) (in query: SELECT count(*) OVER w FROM users WINDOW w AS (ORDER BY uid), w AS(ORDER BY name);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030876372 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:55.995164 [ 1655 ] {805e1727-167c-40f3-877c-a33544ed1047} TCPHandler: Code: 36. DB::Exception: Window 'w' is already defined. In scope SELECT count(*) OVER w FROM users WINDOW w AS (ORDER BY uid ASC), w AS (ORDER BY name ASC). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030876372 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.604673 [ 1580 ] {7970400f-31b3-4f05-907f-8108f61f3414} executeQuery: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 0, should be 2: In scope SELECT __actionName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:36918) (comment: 03035_internal_functions_direct_call.sql) (in query: -- This functions should not be called directly, only for internal use. -- However, we cannot completely forbid it (becasue query can came from another server, for example) -- Check that usage of these functions does not lead to crash or logical error SELECT __actionName();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.605013 [ 1580 ] {7970400f-31b3-4f05-907f-8108f61f3414} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 0, should be 2: In scope SELECT __actionName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.607702 [ 1580 ] {3ade0fc5-c11a-467a-953e-1185d5d73ca3} executeQuery: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName('aaa', 'aaa', 'aaa'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:36918) (comment: 03035_internal_functions_direct_call.sql) (in query: SELECT __actionName('aaa', 'aaa', 'aaa');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.607952 [ 1580 ] {3ade0fc5-c11a-467a-953e-1185d5d73ca3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName('aaa', 'aaa', 'aaa'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.638870 [ 1580 ] {7ec0ac05-d265-495a-887f-f63106d86903} executeQuery: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:36918) (comment: 03035_internal_functions_direct_call.sql) (in query: SELECT __actionName('aaa', '') SETTINGS allow_experimental_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:173: DB::(anonymous namespace)::ActionNodeNameHelper::calculateActionNodeName(std::shared_ptr const&) @ 0x000000002fbac5a2 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:950: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002fbb3c01 6. ./contrib/llvm-project/libcxx/include/vector:556: DB::PlannerActionsVisitor::visit(std::shared_ptr, std::shared_ptr) @ 0x000000002fba94f0 7. ./build_docker/./src/Planner/Utils.cpp:242: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000003102b39b 8. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:360: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x00000000310a604e 9. ./contrib/llvm-project/libcxx/include/vector:1222: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d37e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.639157 [ 1580 ] {7ec0ac05-d265-495a-887f-f63106d86903} TCPHandler: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:173: DB::(anonymous namespace)::ActionNodeNameHelper::calculateActionNodeName(std::shared_ptr const&) @ 0x000000002fbac5a2 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:950: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002fbb3c01 6. ./contrib/llvm-project/libcxx/include/vector:556: DB::PlannerActionsVisitor::visit(std::shared_ptr, std::shared_ptr) @ 0x000000002fba94f0 7. ./build_docker/./src/Planner/Utils.cpp:242: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000003102b39b 8. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:360: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x00000000310a604e 9. ./contrib/llvm-project/libcxx/include/vector:1222: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d37e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.642690 [ 1580 ] {9f517002-27ec-49c6-9e34-959a1f6d19df} executeQuery: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:36918) (comment: 03035_internal_functions_direct_call.sql) (in query: SELECT __actionName('aaa', materialize('aaa'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:173: DB::(anonymous namespace)::ActionNodeNameHelper::calculateActionNodeName(std::shared_ptr const&) @ 0x000000002fbac5a2 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:950: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002fbb3c01 6. ./contrib/llvm-project/libcxx/include/vector:556: DB::PlannerActionsVisitor::visit(std::shared_ptr, std::shared_ptr) @ 0x000000002fba94f0 7. ./build_docker/./src/Planner/Utils.cpp:242: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000003102b39b 8. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:360: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x00000000310a604e 9. ./contrib/llvm-project/libcxx/include/vector:1222: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d37e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.642873 [ 1580 ] {9f517002-27ec-49c6-9e34-959a1f6d19df} TCPHandler: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:173: DB::(anonymous namespace)::ActionNodeNameHelper::calculateActionNodeName(std::shared_ptr const&) @ 0x000000002fbac5a2 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:950: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002fbb3c01 6. ./contrib/llvm-project/libcxx/include/vector:556: DB::PlannerActionsVisitor::visit(std::shared_ptr, std::shared_ptr) @ 0x000000002fba94f0 7. ./build_docker/./src/Planner/Utils.cpp:242: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000003102b39b 8. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:360: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x00000000310a604e 9. ./contrib/llvm-project/libcxx/include/vector:1222: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d37e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.677463 [ 1580 ] {0e8de95a-e6af-422b-9216-f0ff2d636f68} executeQuery: Code: 44. DB::Exception: Argument at index 0 for function __actionName must be constant. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:36918) (comment: 03035_internal_functions_direct_call.sql) (in query: SELECT __actionName(materialize('aaa'), 'aaa');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f0cc 5. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 10. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 12. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.677715 [ 1580 ] {0e8de95a-e6af-422b-9216-f0ff2d636f68} TCPHandler: Code: 44. DB::Exception: Argument at index 0 for function __actionName must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f0cc 5. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 10. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 12. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.743474 [ 1580 ] {005e592c-d26b-4461-98ff-b698db10237d} executeQuery: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly: In scope SELECT concat(__actionName('aaa', toNullable('x')), '1') GROUP BY __actionName('aaa', 'x'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:36918) (comment: 03035_internal_functions_direct_call.sql) (in query: SELECT concat(__actionName('aaa', toNullable('x')), '1') GROUP BY __actionName('aaa', 'x');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionActionName::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cea3b76 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:07:56.743717 [ 1580 ] {005e592c-d26b-4461-98ff-b698db10237d} TCPHandler: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly: In scope SELECT concat(__actionName('aaa', toNullable('x')), '1') GROUP BY __actionName('aaa', 'x'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionActionName::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cea3b76 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:07:56.771157 [ 1580 ] {d678ed14-1f55-464a-b30e-998fafb1d253} executeQuery: Code: 36. DB::Exception: Scalar aaa doesn't exist (internal bug): In scope SELECT __getScalar('aaa'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:36918) (comment: 03035_internal_functions_direct_call.sql) (in query: SELECT __getScalar('aaa');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/Context.cpp:0: DB::Context::getScalar(String const&) const @ 0x000000002fc4ff92 5. DB::(anonymous namespace)::FunctionGetScalar::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bb0ccdc 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.771361 [ 1580 ] {d678ed14-1f55-464a-b30e-998fafb1d253} TCPHandler: Code: 36. DB::Exception: Scalar aaa doesn't exist (internal bug): In scope SELECT __getScalar('aaa'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/Context.cpp:0: DB::Context::getScalar(String const&) const @ 0x000000002fc4ff92 5. DB::(anonymous namespace)::FunctionGetScalar::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bb0ccdc 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.773431 [ 1580 ] {8de80f9b-e842-4b27-8e03-fe9742bbb7bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 0, should be 1: In scope SELECT __getScalar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:36918) (comment: 03035_internal_functions_direct_call.sql) (in query: SELECT __getScalar();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.773549 [ 1580 ] {8de80f9b-e842-4b27-8e03-fe9742bbb7bd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 0, should be 1: In scope SELECT __getScalar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.799309 [ 1580 ] {d13712ba-77e2-4d0c-8e55-45050637b1e5} executeQuery: Code: 43. DB::Exception: Function __getScalar accepts one const string argument: In scope SELECT __getScalar(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:36918) (comment: 03035_internal_functions_direct_call.sql) (in query: SELECT __getScalar(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionGetScalar::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bb0cb8d 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.799670 [ 1580 ] {d13712ba-77e2-4d0c-8e55-45050637b1e5} TCPHandler: Code: 43. DB::Exception: Function __getScalar accepts one const string argument: In scope SELECT __getScalar(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionGetScalar::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bb0cb8d 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.802169 [ 1580 ] {1dbfa855-cd0f-4cd6-9771-295747a2ea7a} executeQuery: Code: 43. DB::Exception: Function __getScalar accepts one const string argument: In scope SELECT __getScalar(materialize('1')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:36918) (comment: 03035_internal_functions_direct_call.sql) (in query: SELECT __getScalar(materialize('1'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionGetScalar::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bb0cb8d 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.802334 [ 1580 ] {1dbfa855-cd0f-4cd6-9771-295747a2ea7a} TCPHandler: Code: 43. DB::Exception: Function __getScalar accepts one const string argument: In scope SELECT __getScalar(materialize('1')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionGetScalar::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bb0cb8d 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.841883 [ 1580 ] {c60e1a54-564b-4ded-a17a-6b1aa1db18e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 2, should be 1: In scope SELECT __scalarSubqueryResult(a, a), materialize('1') AS a. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:36918) (comment: 03035_internal_functions_direct_call.sql) (in query: SELECT __scalarSubqueryResult(a, a), materialize('1') as a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:56.842192 [ 1580 ] {c60e1a54-564b-4ded-a17a-6b1aa1db18e7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 2, should be 1: In scope SELECT __scalarSubqueryResult(a, a), materialize('1') AS a. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:57.619827 [ 1615 ] {c283a5c8-9782-451b-8229-27ec642b67b1} InterpreterCheckQuery: Check query for table test_ln28is6w.tp_1 (0c8a4384-283b-4c25-a81f-727263e3ac93) failed, path 0_6_6_0, reason: Code: 227. DB::Exception: Found unexpected projection directories: pp.proj. (UNEXPECTED_FILE_IN_DATA_PART) (version 24.3.12.76.altinitystable) 2025.03.05 21:07:57.698978 [ 1576 ] {fb819f0d-b26a-47d2-a4fb-648203957d87} executeQuery: Code: 184. DB::Exception: Aggregate function sum(marks) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 24.3.12.76.altinitystable) (from [::1]:36992) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (in query: SELECT ignore(toFixedString('Lambda as function parameter', 28), toNullable(28), ignore(8)), sum(marks) FROM system.parts WHERE database = currentDatabase() GROUP BY GROUPING SETS ((2)) FORMAT Null settings optimize_injective_functions_in_group_by=1, optimize_group_by_function_keys=1, group_by_use_nulls=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030943593 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000030943817 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093adbe 9. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:57.699265 [ 1576 ] {fb819f0d-b26a-47d2-a4fb-648203957d87} TCPHandler: Code: 184. DB::Exception: Aggregate function sum(marks) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030943593 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000030943817 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093adbe 9. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:57.793552 [ 1576 ] {04f65561-b9cf-45b0-8102-31264d51b3d1} executeQuery: Code: 184. DB::Exception: Aggregate function count('Lambda as function parameter') AS c is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 24.3.12.76.altinitystable) (from [::1]:36992) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (in query: SELECT count('Lambda as function parameter') AS c FROM (SELECT ignore(ignore('Lambda as function parameter', 28, 28, 28, 28, 28, 28), 28), materialize('Lambda as function parameter'), 28, 28, 'world', 5 FROM system.numbers WHERE ignore(materialize('Lambda as function parameter'), materialize(toLowCardinality(28)), 28, 28, 28, 28, toUInt128(28)) LIMIT 2) GROUP BY GROUPING SETS ((toLowCardinality(0)), (toLowCardinality(toNullable(28))), (1)) HAVING nullIf(c, 10) < 50 ORDER BY c ASC NULLS FIRST settings group_by_use_nulls=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030943593 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000030943817 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093adbe 9. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:57.794184 [ 1576 ] {04f65561-b9cf-45b0-8102-31264d51b3d1} TCPHandler: Code: 184. DB::Exception: Aggregate function count('Lambda as function parameter') AS c is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030943593 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000030943817 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093adbe 9. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:57.854497 [ 1576 ] {4b9f825c-18a2-4fbe-9e15-aa9835aba52d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Array(Nothing)) of argument of function toUInt8: while executing 'FUNCTION toUInt8(number :: 0) -> toUInt8(number) UInt8 : 1'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:36992) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (in query: SELECT count(arraySplit(number -> toUInt8(number), [arraySplit(x -> toUInt8(number), [])])) FROM numbers(10) GROUP BY number, [number] WITH ROLLUP settings group_by_use_nulls=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018296fac 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./contrib/llvm-project/libcxx/include/vector:537: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002fdbd37f 12. ./src/Functions/FunctionsMiscellaneous.h:50: DB::ExecutableFunctionExpression::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002fbc69bc 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ColumnFunction::reduce() const @ 0x0000000031b24117 18. DB::FunctionArrayMapped, DB::NameArraySplit>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023ddd2ce 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 20. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 21. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 22. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 23. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 24. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 25. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 26. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 28. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 29. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d717 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 2025.03.05 21:07:57.854988 [ 1576 ] {4b9f825c-18a2-4fbe-9e15-aa9835aba52d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Array(Nothing)) of argument of function toUInt8: while executing 'FUNCTION toUInt8(number :: 0) -> toUInt8(number) UInt8 : 1'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018296fac 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./contrib/llvm-project/libcxx/include/vector:537: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002fdbd37f 12. ./src/Functions/FunctionsMiscellaneous.h:50: DB::ExecutableFunctionExpression::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002fbc69bc 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ColumnFunction::reduce() const @ 0x0000000031b24117 18. DB::FunctionArrayMapped, DB::NameArraySplit>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023ddd2ce 19. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 20. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 21. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 22. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 23. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 24. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 25. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 26. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 28. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 29. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d717 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 2025.03.05 21:07:57.983400 [ 730 ] {88bc6982-1e24-4c7a-9608-3ecae217ac44} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 20.95 MiB (attempt to allocate chunk of 1049600 bytes), maximum: 20.00 MiB.: While executing AggregatingTransform: while pushing to view test_rka40ngw.mv (7e160bbb-41a5-4f2c-82e5-cb8fad5f7db7). (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:37008) (comment: 03030_system_flush_distributed_settings.sql) (in query: INSERT INTO test_rka40ngw.ephemeral (key, value) VALUES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000002461f75f 8. ./src/Common/Allocator.h:0: HashTable, HashTableNoState>, HashCRC32, HashTableGrower<4ul>, AllocatorWithStackMemory, 64ul, 1ul>>::resize(unsigned long, unsigned long) @ 0x00000000278976e3 9. ./src/Common/HashTable/HashTable.h:237: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x000000002788b475 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1380: DB::Aggregator::addBatch(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char**, DB::Arena*) @ 0x000000002fe5ead4 11. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x000000002fe5df78 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1228: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x0000000030058084 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000030055b26 14. ./build_docker/./src/Interpreters/Aggregator.cpp:984: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002fef5454 15. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002fe5af09 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1626: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe6411b 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 18. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 21. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 22. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 23. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:753: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000033ca5936 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52c06 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51924 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 29. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 2025.03.05 21:07:57.985606 [ 730 ] {88bc6982-1e24-4c7a-9608-3ecae217ac44} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 20.95 MiB (attempt to allocate chunk of 1049600 bytes), maximum: 20.00 MiB.: While executing AggregatingTransform: while pushing to view test_rka40ngw.mv (7e160bbb-41a5-4f2c-82e5-cb8fad5f7db7). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000002461f75f 8. ./src/Common/Allocator.h:0: HashTable, HashTableNoState>, HashCRC32, HashTableGrower<4ul>, AllocatorWithStackMemory, 64ul, 1ul>>::resize(unsigned long, unsigned long) @ 0x00000000278976e3 9. ./src/Common/HashTable/HashTable.h:237: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x000000002788b475 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1380: DB::Aggregator::addBatch(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char**, DB::Arena*) @ 0x000000002fe5ead4 11. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x000000002fe5df78 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1228: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x0000000030058084 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000030055b26 14. ./build_docker/./src/Interpreters/Aggregator.cpp:984: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002fef5454 15. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002fe5af09 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1626: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe6411b 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 18. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 21. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 22. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 23. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:753: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000033ca5936 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52c06 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51924 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 29. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 2025.03.05 21:07:58.004970 [ 1580 ] {2073f1c8-d157-41f8-a9b6-7efeabbf6585} executeQuery: Code: 241. DB::Exception: Received from localhost:9000. DB::Exception: Memory limit (for query) exceeded: would use 20.95 MiB (attempt to allocate chunk of 1049600 bytes), maximum: 20.00 MiB.: While executing AggregatingTransform: while pushing to view test_rka40ngw.mv (7e160bbb-41a5-4f2c-82e5-cb8fad5f7db7). Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000002461f75f 8. ./src/Common/Allocator.h:0: HashTable, HashTableNoState>, HashCRC32, HashTableGrower<4ul>, AllocatorWithStackMemory, 64ul, 1ul>>::resize(unsigned long, unsigned long) @ 0x00000000278976e3 9. ./src/Common/HashTable/HashTable.h:237: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x000000002788b475 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1380: DB::Aggregator::addBatch(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char**, DB::Arena*) @ 0x000000002fe5ead4 11. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x000000002fe5df78 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1228: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x0000000030058084 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000030055b26 14. ./build_docker/./src/Interpreters/Aggregator.cpp:984: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002fef5454 15. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002fe5af09 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1626: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe6411b 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 18. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 21. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 22. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 23. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:753: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000033ca5936 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52c06 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51924 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 29. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/c55/c550ae98-fb3a-475f-99bc-f3f36a0fce2d/shard1_replica1/1.bin. (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:36988) (comment: 03030_system_flush_distributed_settings.sql) (in query: system flush distributed dist_in;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:129: DB::RemoteInserter::onFinish() @ 0x0000000032923999 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:0: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003291f307 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:119: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&) @ 0x000000003291ac41 9. ./contrib/llvm-project/libcxx/include/__hash_table:340: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(DB::SettingsChanges const&) @ 0x000000003290ce40 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:380: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x0000000032906cde 11. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000032906b09 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e722c80 13. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000295508e1 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:58.005505 [ 1580 ] {2073f1c8-d157-41f8-a9b6-7efeabbf6585} TCPHandler: Code: 241. DB::Exception: Received from localhost:9000. DB::Exception: Memory limit (for query) exceeded: would use 20.95 MiB (attempt to allocate chunk of 1049600 bytes), maximum: 20.00 MiB.: While executing AggregatingTransform: while pushing to view test_rka40ngw.mv (7e160bbb-41a5-4f2c-82e5-cb8fad5f7db7). Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000002461f75f 8. ./src/Common/Allocator.h:0: HashTable, HashTableNoState>, HashCRC32, HashTableGrower<4ul>, AllocatorWithStackMemory, 64ul, 1ul>>::resize(unsigned long, unsigned long) @ 0x00000000278976e3 9. ./src/Common/HashTable/HashTable.h:237: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x000000002788b475 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1380: DB::Aggregator::addBatch(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char**, DB::Arena*) @ 0x000000002fe5ead4 11. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x000000002fe5df78 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1228: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x0000000030058084 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000030055b26 14. ./build_docker/./src/Interpreters/Aggregator.cpp:984: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002fef5454 15. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002fe5af09 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1626: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe6411b 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 18. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 21. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 22. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 23. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:753: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000033ca5936 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52c06 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51924 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 29. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/c55/c550ae98-fb3a-475f-99bc-f3f36a0fce2d/shard1_replica1/1.bin. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:129: DB::RemoteInserter::onFinish() @ 0x0000000032923999 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:0: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003291f307 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:119: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&) @ 0x000000003291ac41 9. ./contrib/llvm-project/libcxx/include/__hash_table:340: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(DB::SettingsChanges const&) @ 0x000000003290ce40 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:380: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x0000000032906cde 11. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000032906b09 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e722c80 13. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000295508e1 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:58.300614 [ 1609 ] {ead0bd35-c66d-4559-a0f5-e5718382968f} test_rka40ngw.dist_in.DistributedInsertQueue.default: File /var/lib/clickhouse/store/c55/c550ae98-fb3a-475f-99bc-f3f36a0fce2d/shard1_replica1/1.bin does not exists, likely due to current_batch.txt processing 2025.03.05 21:07:58.358550 [ 1576 ] {c793a649-a1eb-4371-813e-430877d62101} executeQuery: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.3.12.76.altinitystable) (from [::1]:37062) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: CREATE TABLE data (`key` Int, `value` AggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree ORDER BY (key, value) SETTINGS index_granularity = 62221, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 264634396, compact_parts_max_bytes_to_buffer = 345439551, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 18931937, merge_max_block_size = 8247, old_parts_lifetime = 85., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3990452500, index_granularity_bytes = 14525502, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 14479, primary_key_compress_block_size = 37647), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Storages/KeyDescription.cpp:151: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000320fab75 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:555: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306a4ab 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:58.358911 [ 1576 ] {c793a649-a1eb-4371-813e-430877d62101} TCPHandler: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Storages/KeyDescription.cpp:151: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000320fab75 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:555: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306a4ab 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:58.385647 [ 1576 ] {2399d388-10c5-4834-986e-d85a94831fe9} executeQuery: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.3.12.76.altinitystable) (from [::1]:37062) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: CREATE TABLE data (`key` Int, `value` SimpleAggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree ORDER BY (key, value) SETTINGS index_granularity = 62221, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 264634396, compact_parts_max_bytes_to_buffer = 345439551, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 18931937, merge_max_block_size = 8247, old_parts_lifetime = 85., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3990452500, index_granularity_bytes = 14525502, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 14479, primary_key_compress_block_size = 37647), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x0000000032bdb03f 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306a577 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:58.385923 [ 1576 ] {2399d388-10c5-4834-986e-d85a94831fe9} TCPHandler: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x0000000032bdb03f 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306a577 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:58.389560 [ 1576 ] {bd3cfb42-fb73-4778-a424-ff527f0e94fa} executeQuery: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.3.12.76.altinitystable) (from [::1]:37062) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: CREATE TABLE data (`key` Int, `value` AggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree PRIMARY KEY value SETTINGS index_granularity = 62221, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 264634396, compact_parts_max_bytes_to_buffer = 345439551, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 18931937, merge_max_block_size = 8247, old_parts_lifetime = 85., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3990452500, index_granularity_bytes = 14525502, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 14479, primary_key_compress_block_size = 37647), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Storages/KeyDescription.cpp:151: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000320fab75 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:555: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306a4ab 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:58.389842 [ 1576 ] {bd3cfb42-fb73-4778-a424-ff527f0e94fa} TCPHandler: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Storages/KeyDescription.cpp:151: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000320fab75 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:555: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306a4ab 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:58.393437 [ 1576 ] {ff45eb9c-305b-42ef-b152-09f23b4cb42a} executeQuery: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.3.12.76.altinitystable) (from [::1]:37062) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: CREATE TABLE data (`key` Int, `value` SimpleAggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree PRIMARY KEY value SETTINGS index_granularity = 62221, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 264634396, compact_parts_max_bytes_to_buffer = 345439551, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 18931937, merge_max_block_size = 8247, old_parts_lifetime = 85., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3990452500, index_granularity_bytes = 14525502, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 14479, primary_key_compress_block_size = 37647), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x0000000032bdb03f 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306a577 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:58.393651 [ 1576 ] {ff45eb9c-305b-42ef-b152-09f23b4cb42a} TCPHandler: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x0000000032bdb03f 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306a577 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:58.396299 [ 1576 ] {811c21ab-5099-4338-a70d-df120276a791} executeQuery: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.3.12.76.altinitystable) (from [::1]:37062) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: CREATE TABLE data (`key` Int, `value` AggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree PRIMARY KEY value ORDER BY (value, key) SETTINGS index_granularity = 62221, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 264634396, compact_parts_max_bytes_to_buffer = 345439551, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 18931937, merge_max_block_size = 8247, old_parts_lifetime = 85., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3990452500, index_granularity_bytes = 14525502, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 14479, primary_key_compress_block_size = 37647), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Storages/KeyDescription.cpp:151: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000320fab75 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:555: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306a4ab 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:58.396667 [ 1576 ] {811c21ab-5099-4338-a70d-df120276a791} TCPHandler: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Storages/KeyDescription.cpp:151: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000320fab75 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:555: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306a4ab 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:58.399149 [ 1576 ] {272ad539-37bb-4b14-b39a-8e64b577a05f} executeQuery: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.3.12.76.altinitystable) (from [::1]:37062) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: CREATE TABLE data (`key` Int, `value` SimpleAggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree PRIMARY KEY value ORDER BY (value, key) SETTINGS index_granularity = 62221, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 264634396, compact_parts_max_bytes_to_buffer = 345439551, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 18931937, merge_max_block_size = 8247, old_parts_lifetime = 85., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3990452500, index_granularity_bytes = 14525502, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 14479, primary_key_compress_block_size = 37647), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x0000000032bdb03f 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306a577 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:58.399407 [ 1576 ] {272ad539-37bb-4b14-b39a-8e64b577a05f} TCPHandler: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x0000000032bdb03f 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306a577 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:58.406733 [ 1891 ] {4331ff89-4053-4561-8f39-04654831c507} InterpreterCheckQuery: Check query for table test_ln28is6w.tp_1 (3d56ce47-a65e-4b55-a5c1-4201108661c4) failed, path 0_2_2_0, reason: Code: 227. DB::Exception: Found unexpected projection directories: pp.proj. (UNEXPECTED_FILE_IN_DATA_PART) (version 24.3.12.76.altinitystable) 2025.03.05 21:07:58.450571 [ 1576 ] {df0f6e01-49a8-442c-87db-7ee854bb2354} executeQuery: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.3.12.76.altinitystable) (from [::1]:37062) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: alter table data add column value SimpleAggregateFunction(sum, UInt64), modify order by (key, value);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x0000000032bdb03f 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003307f811 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795294 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:58.450857 [ 1576 ] {df0f6e01-49a8-442c-87db-7ee854bb2354} TCPHandler: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x0000000032bdb03f 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003307f811 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795294 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:58.505900 [ 1576 ] {f27bb199-7e44-4943-9512-c0bdfb5431fb} executeQuery: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.3.12.76.altinitystable) (from [::1]:37062) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: alter table data_rep add column value SimpleAggregateFunction(sum, UInt64), modify order by (key, value);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x0000000032bdb03f 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000324a31db 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795294 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:58.506256 [ 1576 ] {f27bb199-7e44-4943-9512-c0bdfb5431fb} TCPHandler: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x0000000032bdb03f 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000324a31db 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795294 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:07:58.595344 [ 1867 ] {27d8d57e-1a7b-4a62-9e95-4a96b92d56e2} InterpreterCheckQuery: Check query for table test_ln28is6w.tp_1 (3d56ce47-a65e-4b55-a5c1-4201108661c4) failed, path 0_2_2_0, reason: Code: 227. DB::Exception: Found unexpected projection directories: pp.proj. (UNEXPECTED_FILE_IN_DATA_PART) (version 24.3.12.76.altinitystable) 2025.03.05 21:07:58.813176 [ 1230 ] {} test_ln28is6w.tp_1 (3d56ce47-a65e-4b55-a5c1-4201108661c4): Cannot quickly remove directory /var/lib/clickhouse/store/3d5/3d56ce47-a65e-4b55-a5c1-4201108661c4/delete_tmp_0_2_2_0/pp.proj by removing files; fallback to recursive removal. Reason: Code: 458. DB::ErrnoException: Cannot unlink file /var/lib/clickhouse/store/3d5/3d56ce47-a65e-4b55-a5c1-4201108661c4/delete_tmp_0_2_2_0/pp.proj/count.txt: , errno: 2, strerror: No such file or directory. (CANNOT_UNLINK) (version 24.3.12.76.altinitystable) 2025.03.05 21:07:59.390933 [ 1580 ] {9778b00e-5431-4e88-b383-ca59a2257c90} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:60104) (comment: 03021_get_client_http_header.sh) (in query: SELECT getClientHTTPHeader(arrayJoin(['Content-Type', 'Accept']))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000001bb07c82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e84f395 6. ./build_docker/./src/Functions/FunctionFactory.cpp:60: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::CaseSensitiveness)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002e84bd68 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e84cef5 8. ./build_docker/./src/Functions/FunctionFactory.cpp:0: DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002e84abc5 9. ./build_docker/./src/Functions/FunctionFactory.cpp:0: DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002e84b870 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308adea9 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 25. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 26. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:07:59.391265 [ 1580 ] {9778b00e-5431-4e88-b383-ca59a2257c90} DynamicQueryHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000001bb07c82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e84f395 6. ./build_docker/./src/Functions/FunctionFactory.cpp:60: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::CaseSensitiveness)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002e84bd68 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e84cef5 8. ./build_docker/./src/Functions/FunctionFactory.cpp:0: DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002e84abc5 9. ./build_docker/./src/Functions/FunctionFactory.cpp:0: DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002e84b870 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308adea9 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 25. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 26. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 (version 24.3.12.76.altinitystable) 2025.03.05 21:07:59.400575 [ 1580 ] {6743b767-83be-4557-a44b-e64225329266} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:60112) (comment: 03021_get_client_http_header.sh) (in query: SELECT getClientHTTPHeader(arrayJoin(['Content-Type', 'Accept']))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000001bb07c82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e84f395 6. ./build_docker/./src/Functions/FunctionFactory.cpp:60: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::CaseSensitiveness)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002e84bd68 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e84cef5 8. ./build_docker/./src/Functions/FunctionFactory.cpp:0: DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002e84abc5 9. ./build_docker/./src/Functions/FunctionFactory.cpp:0: DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002e84b870 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308adea9 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 25. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 26. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:07:59.401150 [ 1580 ] {6743b767-83be-4557-a44b-e64225329266} DynamicQueryHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000001bb07c82 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e84f395 6. ./build_docker/./src/Functions/FunctionFactory.cpp:60: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr)>::__call_impl (std::shared_ptr)>, DB::FunctionDocumentation, DB::IFactoryWithAliases (std::shared_ptr)>, DB::FunctionDocumentation>>::CaseSensitiveness)::$_0, std::shared_ptr (std::shared_ptr)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000002e84bd68 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e84cef5 8. ./build_docker/./src/Functions/FunctionFactory.cpp:0: DB::FunctionFactory::tryGetImpl(String const&, std::shared_ptr) const @ 0x000000002e84abc5 9. ./build_docker/./src/Functions/FunctionFactory.cpp:0: DB::FunctionFactory::tryGet(String const&, std::shared_ptr) const @ 0x000000002e84b870 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308adea9 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 25. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 26. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 (version 24.3.12.76.altinitystable) 2025.03.05 21:07:59.554927 [ 730 ] {ce82d6a7-8501-43cd-a37e-426ae6fb370c} executeQuery: Code: 36. DB::Exception: Time overflow in function hop: In scope SELECT hop(toDateTime(0), toIntervalDay(1), toIntervalDay(3)). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:38346) (comment: 03013_hop_infinite_loop.sql) (in query: SELECT hop(toDateTime(0), INTERVAL 1 DAY, INTERVAL 3 DAY);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::(anonymous namespace)::TimeWindowImpl<(DB::(anonymous namespace)::TimeWindowFunctionName)3>::dispatchForColumns(std::vector> const&, String const&) @ 0x00000000193d7d82 5. DB::(anonymous namespace)::FunctionTimeWindow<(DB::(anonymous namespace)::TimeWindowFunctionName)3>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000193d4359 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:07:59.555164 [ 730 ] {ce82d6a7-8501-43cd-a37e-426ae6fb370c} TCPHandler: Code: 36. DB::Exception: Time overflow in function hop: In scope SELECT hop(toDateTime(0), toIntervalDay(1), toIntervalDay(3)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::(anonymous namespace)::TimeWindowImpl<(DB::(anonymous namespace)::TimeWindowFunctionName)3>::dispatchForColumns(std::vector> const&, String const&) @ 0x00000000193d7d82 5. DB::(anonymous namespace)::FunctionTimeWindow<(DB::(anonymous namespace)::TimeWindowFunctionName)3>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000193d4359 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:08:00.089069 [ 1580 ] {5c2c4678-8556-4330-a21d-e3b29ddc9a6e} executeQuery: Code: 471. DB::Exception: Sanity check: 'poll_max_batch_size' value is too high (18446744073709). (INVALID_SETTING_VALUE) (version 24.3.12.76.altinitystable) (from [::1]:38428) (comment: 03010_file_log_large_poll_batch_size.sql) (in query: create table test (number UInt64) engine=FileLog('./user_files/data.jsonl', 'JSONEachRow') settings poll_max_batch_size=18446744073709;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x00000000307da1bb 4. ./build_docker/./src/Storages/FileLog/FileLogSettings.cpp:44: DB::FileLogSettings::loadFromQuery(DB::ASTStorage&) @ 0x0000000032763e14 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:808: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000327380f1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.117034 [ 1580 ] {5c2c4678-8556-4330-a21d-e3b29ddc9a6e} TCPHandler: Code: 471. DB::Exception: Sanity check: 'poll_max_batch_size' value is too high (18446744073709). (INVALID_SETTING_VALUE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x00000000307da1bb 4. ./build_docker/./src/Storages/FileLog/FileLogSettings.cpp:44: DB::FileLogSettings::loadFromQuery(DB::ASTStorage&) @ 0x0000000032763e14 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:808: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000327380f1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.117037 [ 2280 ] {1a7b591b-7e91-40a0-a5c4-c6e0c0381d4b} executeQuery: Code: 6. DB::Exception: Cannot parse string 'NULL' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION CAST(__table1.x :: 3, 'UInt8'_String :: 1) -> CAST(__table1.x, 'UInt8'_String) UInt8 : 0'. (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:38404) (comment: 03011_definitive_guide_to_cast.sql) (in query: SELECT CAST(x AS UInt8) AS y, toTypeName(y) FROM VALUES('x Nullable(String)', ('123'), ('NULL'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182a05c1 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018296bef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000185cb222 14. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 17. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.117298 [ 2280 ] {1a7b591b-7e91-40a0-a5c4-c6e0c0381d4b} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'NULL' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION CAST(__table1.x :: 3, 'UInt8'_String :: 1) -> CAST(__table1.x, 'UInt8'_String) UInt8 : 0'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182a05c1 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018296bef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000185cb222 14. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 17. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.162645 [ 2280 ] {448899c1-0ebd-453d-823a-a897bcf7cd5c} executeQuery: Code: 72. DB::Exception: Unsigned type must not contain '-' symbol: Cannot parse UInt8 from String: In scope SELECT CAST('-123', 'UInt8'). (CANNOT_PARSE_NUMBER) (version 24.3.12.76.altinitystable) (from [::1]:38404) (comment: 03011_definitive_guide_to_cast.sql) (in query: SELECT CAST('-123' AS UInt8);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::readIntTextImpl(char8_t&, DB::ReadBuffer&) @ 0x000000001878b347 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001829e05e 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018296bef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 17. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 19. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 24. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 30. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 2025.03.05 21:08:00.162896 [ 2280 ] {448899c1-0ebd-453d-823a-a897bcf7cd5c} TCPHandler: Code: 72. DB::Exception: Unsigned type must not contain '-' symbol: Cannot parse UInt8 from String: In scope SELECT CAST('-123', 'UInt8'). (CANNOT_PARSE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::readIntTextImpl(char8_t&, DB::ReadBuffer&) @ 0x000000001878b347 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001829e05e 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018296bef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 17. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 19. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 24. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 30. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 2025.03.05 21:08:00.196575 [ 2280 ] {9459cdaa-e5e6-4816-83c8-025b04534abc} executeQuery: Code: 6. DB::Exception: Cannot parse string ' 123' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST(' 123', 'UInt8'). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:38404) (comment: 03011_definitive_guide_to_cast.sql) (in query: -- Parsing from a string does not tolerate extra whitespace characters: SELECT CAST(' 123' AS UInt8);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182a05c1 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018296bef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 17. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 19. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 24. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 30. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 2025.03.05 21:08:00.196833 [ 2280 ] {9459cdaa-e5e6-4816-83c8-025b04534abc} TCPHandler: Code: 6. DB::Exception: Cannot parse string ' 123' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST(' 123', 'UInt8'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182a05c1 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018296bef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 17. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 19. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 24. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 30. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 2025.03.05 21:08:00.199126 [ 2280 ] {10a31659-5474-4d2a-941b-3d433670d60b} executeQuery: Code: 6. DB::Exception: Cannot parse string '123 ' as UInt8: syntax error at position 3 (parsed just '123'). Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST('123 ', 'UInt8'). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:38404) (comment: 03011_definitive_guide_to_cast.sql) (in query: SELECT CAST('123 ' AS UInt8);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182a05c1 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018296bef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 17. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 19. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 24. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 30. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 2025.03.05 21:08:00.199276 [ 2280 ] {10a31659-5474-4d2a-941b-3d433670d60b} TCPHandler: Code: 6. DB::Exception: Cannot parse string '123 ' as UInt8: syntax error at position 3 (parsed just '123'). Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST('123 ', 'UInt8'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182a05c1 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018296bef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 17. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 19. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 24. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 30. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 2025.03.05 21:08:00.264951 [ 2280 ] {2c03f566-fb87-4e61-b0e9-8ebc81a862f6} executeQuery: Code: 407. DB::Exception: DateTime64 convert overflow. Float is out of Decimal range: In scope SELECT CAST(100000000000000000000., 'DateTime64(9, \'Europe/Amsterdam\')'). (DECIMAL_OVERFLOW) (version 24.3.12.76.altinitystable) (from [::1]:38404) (comment: 03011_definitive_guide_to_cast.sql) (in query: -- A special case is DateTime64(9) - the maximum resolution, where is does not cover the usual range, -- and in this case, it throws an exception on overflow (I don't mind if we change this behavior in the future): SELECT CAST(1e20 AS DateTime64(9, 'Europe/Amsterdam'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:0: void DB::convertToDecimalImpl, DB::DataTypeDateTime64, void>(DB::DataTypeNumber::FieldType const&, unsigned int, DB::DataTypeDateTime64::FieldType&) @ 0x000000002f521d60 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: DB::DataTypeDateTime64::FieldType DB::convertToDecimal, DB::DataTypeDateTime64>(DB::DataTypeNumber::FieldType const&, unsigned int) @ 0x000000002f524f39 6. void DB::Transformer, DB::DataTypeDateTime64, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000184bdcf5 7. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime64, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0> const&) @ 0x00000000184bd5f1 8. bool DB::callOnIndexAndDataType::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper(std::shared_ptr const&, DB::DataTypeDateTime64 const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDateTime64 const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper(std::shared_ptr const&, DB::DataTypeDateTime64 const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDateTime64 const&)&&) @ 0x00000000184e998d 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper(std::shared_ptr const&, DB::DataTypeDateTime64 const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000184e9063 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 14. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:08:00.265267 [ 2280 ] {2c03f566-fb87-4e61-b0e9-8ebc81a862f6} TCPHandler: Code: 407. DB::Exception: DateTime64 convert overflow. Float is out of Decimal range: In scope SELECT CAST(100000000000000000000., 'DateTime64(9, \'Europe/Amsterdam\')'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:0: void DB::convertToDecimalImpl, DB::DataTypeDateTime64, void>(DB::DataTypeNumber::FieldType const&, unsigned int, DB::DataTypeDateTime64::FieldType&) @ 0x000000002f521d60 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: DB::DataTypeDateTime64::FieldType DB::convertToDecimal, DB::DataTypeDateTime64>(DB::DataTypeNumber::FieldType const&, unsigned int) @ 0x000000002f524f39 6. void DB::Transformer, DB::DataTypeDateTime64, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000184bdcf5 7. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime64, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0> const&) @ 0x00000000184bd5f1 8. bool DB::callOnIndexAndDataType::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper(std::shared_ptr const&, DB::DataTypeDateTime64 const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDateTime64 const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper(std::shared_ptr const&, DB::DataTypeDateTime64 const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDateTime64 const&)&&) @ 0x00000000184e998d 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper(std::shared_ptr const&, DB::DataTypeDateTime64 const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000184e9063 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 14. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:08:00.315173 [ 2280 ] {d1f6a8bf-d6a8-40dc-a2b8-4188582191b5} executeQuery: Code: 131. DB::Exception: String too long for type FixedString(3): In scope SELECT CAST('12345', 'FixedString(3)'). (TOO_LARGE_STRING_SIZE) (version 24.3.12.76.altinitystable) (from [::1]:38404) (comment: 03011_definitive_guide_to_cast.sql) (in query: -- But if it does not fit, an exception is thrown: SELECT CAST('12345' AS FixedString(3)) FORMAT TSV;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. COW::immutable_ptr DB::FunctionToFixedString::executeForN<(DB::ConvertToFixedStringExceptionMode)0>(std::vector> const&, unsigned long) @ 0x00000000187d8b47 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, unsigned long) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001853a6c4 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:08:00.315452 [ 2280 ] {d1f6a8bf-d6a8-40dc-a2b8-4188582191b5} TCPHandler: Code: 131. DB::Exception: String too long for type FixedString(3): In scope SELECT CAST('12345', 'FixedString(3)'). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. COW::immutable_ptr DB::FunctionToFixedString::executeForN<(DB::ConvertToFixedStringExceptionMode)0>(std::vector> const&, unsigned long) @ 0x00000000187d8b47 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, unsigned long) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001853a6c4 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:08:00.372999 [ 2280 ] {db7c4cf7-b088-46ed-ab53-53c4001710ba} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'String' in scope SELECT CAST(123, String). (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:38404) (comment: 03011_definitive_guide_to_cast.sql) (in query: SELECT CAST(123, String);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.373190 [ 2280 ] {db7c4cf7-b088-46ed-ab53-53c4001710ba} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'String' in scope SELECT CAST(123, String). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.381259 [ 2280 ] {7c61a4b8-25b2-4956-84ec-a2b42397a3bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 1, should be 2: In scope SELECT _CAST(123 AS UInt8). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:38404) (comment: 03011_definitive_guide_to_cast.sql) (in query: -- There is no operator form of this function: -- does not work, here UInt8 is interpreted as an alias for the value: SELECT _CAST(123 AS UInt8);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.381406 [ 2280 ] {7c61a4b8-25b2-4956-84ec-a2b42397a3bb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 1, should be 2: In scope SELECT _CAST(123 AS UInt8). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.421840 [ 2280 ] {10d73201-096e-4c77-a490-eef6b0e991c6} executeQuery: Code: 72. DB::Exception: Unsigned type must not contain '-' symbol: Cannot parse UInt64 from String: In scope SELECT CAST('-1', 'UInt64'). (CANNOT_PARSE_NUMBER) (version 24.3.12.76.altinitystable) (from [::1]:38404) (comment: 03011_definitive_guide_to_cast.sql) (in query: -- We can change this behavior in the future. -- Another example: SELECT -1::UInt64;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::readIntTextImpl(unsigned long&, DB::ReadBuffer&) @ 0x0000000018792949 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182e8998 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182e12ef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 17. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 19. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 24. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 30. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 2025.03.05 21:08:00.422018 [ 2280 ] {10d73201-096e-4c77-a490-eef6b0e991c6} TCPHandler: Code: 72. DB::Exception: Unsigned type must not contain '-' symbol: Cannot parse UInt64 from String: In scope SELECT CAST('-1', 'UInt64'). (CANNOT_PARSE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::readIntTextImpl(unsigned long&, DB::ReadBuffer&) @ 0x0000000018792949 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182e8998 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182e12ef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 17. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 19. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 24. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 30. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 2025.03.05 21:08:00.459295 [ 2280 ] {07cec5bf-0658-485b-9b7c-c71207962945} executeQuery: Code: 43. DB::Exception: Illegal types UInt8 and String of arguments of function minus: In scope SELECT 1 - CAST('1', 'String'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:38404) (comment: 03011_definitive_guide_to_cast.sql) (in query: -- The operator has the highest priority among others: SELECT 1-1::String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001efa79cf 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.459523 [ 2280 ] {07cec5bf-0658-485b-9b7c-c71207962945} TCPHandler: Code: 43. DB::Exception: Illegal types UInt8 and String of arguments of function minus: In scope SELECT 1 - CAST('1', 'String'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001efa79cf 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.488445 [ 2280 ] {7a65fed2-ae38-4e92-814a-e4850765e4e0} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function negate: In scope SELECT 1 AS x, -CAST(x, 'String'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:38404) (comment: 03011_definitive_guide_to_cast.sql) (in query: -- Here it is an operator: SELECT 1 AS x, -x::String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000002015b379 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.488736 [ 2280 ] {7a65fed2-ae38-4e92-814a-e4850765e4e0} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function negate: In scope SELECT 1 AS x, -CAST(x, 'String'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000002015b379 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.518588 [ 2280 ] {ea796d7e-73de-4dab-91bc-cecbc3798cea} executeQuery: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type Float32: In scope SELECT accurateCast(1.123456789, 'Float32'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:38404) (comment: 03011_definitive_guide_to_cast.sql) (in query: -- 5. Accurate casting functions: `accurateCast`, `accurateCastOrNull`, `accurateCastOrDefault`. -- These functions check if the value is exactly representable in the target data type. -- The function `accurateCast` performs the conversion or throws an exception if the value is not exactly representable: SELECT accurateCast(1.123456789, 'Float32');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000183cdad0 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000183c735b 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:08:00.518811 [ 2280 ] {ea796d7e-73de-4dab-91bc-cecbc3798cea} TCPHandler: Code: 70. DB::Exception: Value in column Float64 cannot be safely converted into type Float32: In scope SELECT accurateCast(1.123456789, 'Float32'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000183cdad0 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000183c735b 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:08:00.541898 [ 1580 ] {c2acf20d-84ae-4bb7-a86f-250f316c0269} executeQuery: Code: 452. DB::Exception: Min. bytes / rows must be set with a max. (SETTING_CONSTRAINT_VIOLATION) (version 24.3.12.76.altinitystable) (from [::1]:38462) (comment: 03009_storage_memory_circ_buffer_usage.sql) (in query: CREATE TABLE faulty_memory (i UInt32) ENGINE = Memory SETTINGS min_rows_to_keep = 100;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageMemory.cpp:571: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000032303a8b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.561111 [ 2280 ] {34648b2a-1009-4e77-910f-f27c82b79730} executeQuery: Code: 46. DB::Exception: Function with name 'ACCURATECAST' does not exist. In scope SELECT ACCURATECAST(1, 'String'). Maybe you meant: ['accurateCast']. (UNKNOWN_FUNCTION) (version 24.3.12.76.altinitystable) (from [::1]:38404) (comment: 03011_definitive_guide_to_cast.sql) (in query: -- Unfortunately, this does not work as expected: SELECT accurateCastOrDefault(-1, $$Enum8('None' = 1, 'Hello' = 2, 'World' = 3)$$); -- https://github.com/ClickHouse/ClickHouse/issues/61495 -- These functions are case-sensitive, and there are no corresponding operators: SELECT ACCURATECAST(1, 'String');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000002951b6a3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b7ba1 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.561129 [ 1580 ] {c2acf20d-84ae-4bb7-a86f-250f316c0269} TCPHandler: Code: 452. DB::Exception: Min. bytes / rows must be set with a max. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageMemory.cpp:571: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000032303a8b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.561339 [ 2280 ] {34648b2a-1009-4e77-910f-f27c82b79730} TCPHandler: Code: 46. DB::Exception: Function with name 'ACCURATECAST' does not exist. In scope SELECT ACCURATECAST(1, 'String'). Maybe you meant: ['accurateCast']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000002951b6a3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b7ba1 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.563904 [ 1580 ] {5e9e1947-361b-4f4c-a3d9-e5d97052c93d} executeQuery: Code: 452. DB::Exception: Min. bytes / rows must be set with a max. (SETTING_CONSTRAINT_VIOLATION) (version 24.3.12.76.altinitystable) (from [::1]:38462) (comment: 03009_storage_memory_circ_buffer_usage.sql) (in query: CREATE TABLE faulty_memory (i UInt32) ENGINE = Memory SETTINGS min_bytes_to_keep = 100;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageMemory.cpp:571: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000032303a8b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.564033 [ 1580 ] {5e9e1947-361b-4f4c-a3d9-e5d97052c93d} TCPHandler: Code: 452. DB::Exception: Min. bytes / rows must be set with a max. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageMemory.cpp:571: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000032303a8b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.650167 [ 2280 ] {8194c2dc-692b-4b00-8b71-b29ebff25e13} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of first argument of function toUInt8OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt8OrNull(123). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:38404) (comment: 03011_definitive_guide_to_cast.sql) (in query: -- These functions are only applicable to string data types. -- Although it is a room for extension: SELECT toUInt8OrNull(123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionConvertFromString, DB::(anonymous namespace)::NameToUInt8OrNull, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)2, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186dcc85 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.652914 [ 2280 ] {8194c2dc-692b-4b00-8b71-b29ebff25e13} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of first argument of function toUInt8OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt8OrNull(123). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionConvertFromString, DB::(anonymous namespace)::NameToUInt8OrNull, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)2, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186dcc85 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.902064 [ 1655 ] {14f682c4-b9d1-4981-b801-eef68b48a591} executeQuery: Code: 42. DB::Exception: Table function 'executable' requires minimum 3 arguments: script_name, format, structure, [input_query...]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:38500) (comment: 03006_analyzer_executable_table_function.sql) (in query: SELECT toFixedString(toFixedString(toLowCardinality(toFixedString('--------------------', toNullable(20))), toLowCardinality(20)), 20), * FROM executable('data String', SETTINGS max_command_execution_time = 100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:0: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e45e209 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:00.902315 [ 1655 ] {14f682c4-b9d1-4981-b801-eef68b48a591} TCPHandler: Code: 42. DB::Exception: Table function 'executable' requires minimum 3 arguments: script_name, format, structure, [input_query...]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:0: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e45e209 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:01.079461 [ 1655 ] {1f9fac75-b633-4c7e-b684-7d4bf7c0bc67} executeQuery: Code: 36. DB::Exception: Incorrect argument 2 type of function arrayEnumerateUniqRanked. Expected an Array or Const(UInt64), got UInt8: In scope SELECT arrayEnumerateUniqRanked(arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]]), materialize(1 AS x) OR toLowCardinality(-9223372036854775808)). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:38506) (comment: 03003_arrayEnumerate_crash.sql) (in query: SELECT arrayEnumerateUniqRanked(arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]]), materialize(1 AS x) OR toLowCardinality(-9223372036854775808));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, char const*&, String&&) @ 0x0000000023c7b27b 4. DB::getArraysDepths(std::vector> const&, char const*) @ 0x0000000023c7abaf 5. DB::FunctionArrayEnumerateRankedExtended::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023c94d5d 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:01.079720 [ 1655 ] {1f9fac75-b633-4c7e-b684-7d4bf7c0bc67} TCPHandler: Code: 36. DB::Exception: Incorrect argument 2 type of function arrayEnumerateUniqRanked. Expected an Array or Const(UInt64), got UInt8: In scope SELECT arrayEnumerateUniqRanked(arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]]), materialize(1 AS x) OR toLowCardinality(-9223372036854775808)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, char const*&, String&&) @ 0x0000000023c7b27b 4. DB::getArraysDepths(std::vector> const&, char const*) @ 0x0000000023c7abaf 5. DB::FunctionArrayEnumerateRankedExtended::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023c94d5d 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:01.082703 [ 1655 ] {0ded2146-05ad-4d39-8e3e-72f6429e0391} executeQuery: Code: 36. DB::Exception: Incorrect argument 2 type of function arrayEnumerateUniqRanked. Expected an Array or Const(UInt64), got UInt64: In scope SELECT arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]], number) FROM numbers(10). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:38506) (comment: 03003_arrayEnumerate_crash.sql) (in query: SELECT arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]], number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, char const*&, String&&) @ 0x0000000023c7b27b 4. DB::getArraysDepths(std::vector> const&, char const*) @ 0x0000000023c7abaf 5. DB::FunctionArrayEnumerateRankedExtended::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023c94d5d 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:01.082881 [ 1655 ] {0ded2146-05ad-4d39-8e3e-72f6429e0391} TCPHandler: Code: 36. DB::Exception: Incorrect argument 2 type of function arrayEnumerateUniqRanked. Expected an Array or Const(UInt64), got UInt64: In scope SELECT arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]], number) FROM numbers(10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, char const*&, String&&) @ 0x0000000023c7b27b 4. DB::getArraysDepths(std::vector> const&, char const*) @ 0x0000000023c7abaf 5. DB::FunctionArrayEnumerateRankedExtended::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023c94d5d 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:02.330369 [ 1580 ] {aec1fec8-e27f-48d7-805d-cab0f88de38e} DynamicQueryHandler: Code: 246. DB::Exception: Too large uncompressed size: 4294967295. (CORRUPTED_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x000000002e97541a 4. ./build_docker/./src/Compression/CompressionCodecMultiple.cpp:0: DB::CompressionCodecMultiple::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x000000002f39b878 5. ./build_docker/./src/Compression/ICompressionCodec.cpp:110: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x000000002f3d6095 6. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:0: DB::CompressedReadBuffer::nextImpl() @ 0x000000002f377e0e 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc149b4 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x00000000317022e2 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 14. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:02.359500 [ 1580 ] {5992cf8d-9aa9-44de-8300-ffc8fb048c8d} DynamicQueryHandler: Code: 246. DB::Exception: Wrong data for compression codec NONE: source_size (278) != uncompressed_size (33686018). (CORRUPTED_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, unsigned int&) @ 0x000000002e4209c0 4. ./build_docker/./src/Compression/CompressionCodecNone.cpp:33: DB::CompressionCodecNone::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x000000002f391eda 5. ./build_docker/./src/Compression/ICompressionCodec.cpp:110: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x000000002f3d6095 6. ./src/Common/PODArray.h:158: DB::CompressionCodecMultiple::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x000000002f39b4a3 7. ./build_docker/./src/Compression/ICompressionCodec.cpp:110: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x000000002f3d6095 8. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:0: DB::CompressedReadBuffer::nextImpl() @ 0x000000002f377e0e 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc149b4 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x00000000317022e2 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 16. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:02.516869 [ 2623 ] {19127c1b-bedc-4526-9db5-9f6db1964558} executeQuery: Code: 122. DB::Exception: Tables have different structure. (INCOMPATIBLE_COLUMNS) (version 24.3.12.76.altinitystable) (from [::1]:38586) (comment: 02998_attach_partition_not_allowed_if_structure_differs_due_to_materialized_column.sql) (in query: ALTER TABLE attach_partition_t8 ATTACH PARTITION ID '1' FROM attach_partition_t7;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000032bb4251 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x00000000330ba768 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032b81d41 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307959bb 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:02.517201 [ 2623 ] {19127c1b-bedc-4526-9db5-9f6db1964558} TCPHandler: Code: 122. DB::Exception: Tables have different structure. (INCOMPATIBLE_COLUMNS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000032bb4251 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x00000000330ba768 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032b81d41 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307959bb 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:02.792093 [ 1655 ] {9bb9353c-481b-4cbd-81e0-18cb0346082e} executeQuery: Code: 62. DB::Exception: Function with name 'plus' cannot use RESPECT NULLS. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:38644) (comment: 02998_operator_respect_nulls.sql) (in query: SELECT plus(1, 1) RESPECT NULLS;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x00000000290c90b3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5300: DB::(anonymous namespace)::(anonymous namespace)::checkFunctionNodeHasEmptyNullsAction(DB::FunctionNode const&) @ 0x00000000308bada2 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308adf4f 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:02.792302 [ 1655 ] {9bb9353c-481b-4cbd-81e0-18cb0346082e} TCPHandler: Code: 62. DB::Exception: Function with name 'plus' cannot use RESPECT NULLS. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x00000000290c90b3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5300: DB::(anonymous namespace)::(anonymous namespace)::checkFunctionNodeHasEmptyNullsAction(DB::FunctionNode const&) @ 0x00000000308bada2 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308adf4f 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:03.443699 [ 2623 ] {8ec30546-0239-45b3-b52a-40472ffc7d2c} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toNullable('stddevSampOrNull'), [1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:38754) (comment: 02996_nullable_arrayReduce.sql) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/59600 SELECT arrayReduce(toNullable('stddevSampOrNull'), [1]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023d95467 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:03.443964 [ 2623 ] {8ec30546-0239-45b3-b52a-40472ffc7d2c} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toNullable('stddevSampOrNull'), [1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023d95467 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:03.446604 [ 2623 ] {dab71724-77ec-46a8-8d8f-544021eb710b} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toNullable('median'), [toDecimal32OrNull(toFixedString('1', 1), 2), 8]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:38754) (comment: 02996_nullable_arrayReduce.sql) (in query: SELECT arrayReduce(toNullable('median'), [toDecimal32OrNull(toFixedString('1', 1), 2), 8]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023d95467 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:03.446717 [ 2623 ] {dab71724-77ec-46a8-8d8f-544021eb710b} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toNullable('median'), [toDecimal32OrNull(toFixedString('1', 1), 2), 8]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023d95467 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:03.449598 [ 2623 ] {92135b28-54d2-48fb-81c2-da7e7ca6b783} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT toFixedString('--- Int Empty ---', toLowCardinality(17)), arrayReduce(toNullable('avgOrNull'), [1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:38754) (comment: 02996_nullable_arrayReduce.sql) (in query: SELECT toFixedString('--- Int Empty ---', toLowCardinality(17)), arrayReduce(toNullable('avgOrNull'), [1]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023d95467 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:03.449712 [ 2623 ] {92135b28-54d2-48fb-81c2-da7e7ca6b783} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT toFixedString('--- Int Empty ---', toLowCardinality(17)), arrayReduce(toNullable('avgOrNull'), [1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023d95467 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:03.491225 [ 2623 ] {d412d169-5817-47be-9562-e3b1a32906c4} executeQuery: Code: 43. DB::Exception: Argument 1 for function arrayReduce must be an array but it has type Nullable(UInt8).: In scope SELECT arrayReduce('any', toNullable(3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:38754) (comment: 02996_nullable_arrayReduce.sql) (in query: SELECT arrayReduce('any', toNullable(3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x0000000021650631 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023d951f2 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:03.491370 [ 2623 ] {d412d169-5817-47be-9562-e3b1a32906c4} TCPHandler: Code: 43. DB::Exception: Argument 1 for function arrayReduce must be an array but it has type Nullable(UInt8).: In scope SELECT arrayReduce('any', toNullable(3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x0000000021650631 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023d951f2 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:03.493808 [ 2623 ] {9363e376-1bf2-4642-92d9-b8f8b0f97fe0} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toLowCardinality('median'), [toLowCardinality(toNullable(8))]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:38754) (comment: 02996_nullable_arrayReduce.sql) (in query: SELECT arrayReduce(toLowCardinality('median'), [toLowCardinality(toNullable(8))]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023d95467 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:03.495904 [ 2623 ] {9363e376-1bf2-4642-92d9-b8f8b0f97fe0} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toLowCardinality('median'), [toLowCardinality(toNullable(8))]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023d95467 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:04.364413 [ 1580 ] {c1e6d8a2-f8ac-45c8-941f-e285d9d70543} executeQuery: Code: 70. DB::Exception: Field value -1 is out of range of unsigned long type. (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:38850) (comment: 02992_settings_overflow.sql) (in query: SET max_threads = -1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Field const&, String&&) @ 0x000000002f370b1b 4. ./build_docker/./src/Core/SettingsFields.cpp:0: unsigned long DB::(anonymous namespace)::fieldToNumber(DB::Field const&) @ 0x000000002f36887b 5. ./src/Core/SettingsFields.h:148: DB::SettingFieldMaxThreads::SettingFieldMaxThreads(DB::Field const&) @ 0x000000002f36b6ae 6. ./build_docker/./src/Core/Settings.cpp:21: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda31'(DB::Field const&)::__invoke(DB::Field const&) @ 0x000000002f1ca59d 7. ./src/Core/Settings.h:0: DB::BaseSettings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x000000002eed3dee 8. ./build_docker/./src/Access/SettingsConstraints.cpp:0: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x000000002eed26d1 9. ./build_docker/./src/Access/SettingsConstraints.cpp:285: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a3d 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002eed0ee2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002fc65656 12. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x00000000310cdc3d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:04.364629 [ 1580 ] {c1e6d8a2-f8ac-45c8-941f-e285d9d70543} TCPHandler: Code: 70. DB::Exception: Field value -1 is out of range of unsigned long type. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Field const&, String&&) @ 0x000000002f370b1b 4. ./build_docker/./src/Core/SettingsFields.cpp:0: unsigned long DB::(anonymous namespace)::fieldToNumber(DB::Field const&) @ 0x000000002f36887b 5. ./src/Core/SettingsFields.h:148: DB::SettingFieldMaxThreads::SettingFieldMaxThreads(DB::Field const&) @ 0x000000002f36b6ae 6. ./build_docker/./src/Core/Settings.cpp:21: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda31'(DB::Field const&)::__invoke(DB::Field const&) @ 0x000000002f1ca59d 7. ./src/Core/Settings.h:0: DB::BaseSettings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x000000002eed3dee 8. ./build_docker/./src/Access/SettingsConstraints.cpp:0: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x000000002eed26d1 9. ./build_docker/./src/Access/SettingsConstraints.cpp:285: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a3d 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002eed0ee2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002fc65656 12. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x00000000310cdc3d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:04.409294 [ 2623 ] {53a30a53-1d1f-4a09-b3dc-c2a4bd9cd749} executeQuery: Code: 497. DB::Exception: user2_03006_test_dwvjvqdw_7156: Not enough privileges. To execute this query, it's necessary to have the grant SELECT ON *.* WITH GRANT OPTION. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:38856) (comment: 03006_correct_revoke_for_partial_rights.sh) (in query: REVOKE ALL ON *.* FROM user1_03006_test_dwvjvqdw_28365), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper(DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed8adcb 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper(DB::AccessFlags) const @ 0x000000002ed89ca2 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(DB::AccessRightsElement const&) const @ 0x000000002ed7b90f 7. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkGrantOption(DB::AccessRightsElements const&) const @ 0x000000002ed2b4a0 8. ./build_docker/./src/Interpreters/Access/InterpreterGrantQuery.cpp:0: DB::InterpreterGrantQuery::execute() @ 0x000000003189496a 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:04.410584 [ 2623 ] {53a30a53-1d1f-4a09-b3dc-c2a4bd9cd749} TCPHandler: Code: 497. DB::Exception: user2_03006_test_dwvjvqdw_7156: Not enough privileges. To execute this query, it's necessary to have the grant SELECT ON *.* WITH GRANT OPTION. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper(DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed8adcb 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper(DB::AccessFlags) const @ 0x000000002ed89ca2 6. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(DB::AccessRightsElement const&) const @ 0x000000002ed7b90f 7. ./build_docker/./src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkGrantOption(DB::AccessRightsElements const&) const @ 0x000000002ed2b4a0 8. ./build_docker/./src/Interpreters/Access/InterpreterGrantQuery.cpp:0: DB::InterpreterGrantQuery::execute() @ 0x000000003189496a 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:04.648560 [ 3094 ] {5681d10a-4827-406a-9d54-bcbe494e2472} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Variant(String, UInt64), UInt8) of function equals: In scope SELECT * FROM test WHERE v = 42. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:38890) (comment: 02990_variant_where_cond.sql) (in query: select * from test where v = 42;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b186fc4 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:04.649018 [ 3094 ] {5681d10a-4827-406a-9d54-bcbe494e2472} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Variant(String, UInt64), UInt8) of function equals: In scope SELECT * FROM test WHERE v = 42. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b186fc4 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:05.104543 [ 3094 ] {91761337-1aba-45dd-9233-8382210241c6} executeQuery: Code: 47. DB::Exception: JOIN test_hm34i6jk.tb ALL INNER JOIN test_hm34i6jk.ta USING (b) using identifier 'b' cannot be resolved from right table expression. In scope SELECT 1 AS b FROM tb INNER JOIN ta USING (b). (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:38936) (comment: 02989_join_using_parent_scope.sql) (in query: SELECT 1 AS b FROM tb JOIN ta USING (b);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dffcf 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:05.104771 [ 3094 ] {91761337-1aba-45dd-9233-8382210241c6} TCPHandler: Code: 47. DB::Exception: JOIN test_hm34i6jk.tb ALL INNER JOIN test_hm34i6jk.ta USING (b) using identifier 'b' cannot be resolved from right table expression. In scope SELECT 1 AS b FROM tb INNER JOIN ta USING (b). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dffcf 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:05.312507 [ 3094 ] {0f37a4ca-a6b0-4f42-b608-c453345202fd} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'a' in scope SELECT a + 2 AS b FROM test_hm34i6jk.tb. Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:38936) (comment: 02989_join_using_parent_scope.sql) (in query: -- It's a default behavior for old analyzer and new with analyzer_compatibility_join_using_top_level_identifier -- Column `b` actually exists in left table, but `b` from USING is resoled to `a + 2` and `a` is not in left table -- so we get UNKNOWN_IDENTIFIER error. SELECT a + 2 AS b FROM tb JOIN tabc USING (b) ORDER BY ALL SETTINGS analyzer_compatibility_join_using_top_level_identifier = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308ddd34 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:05.312785 [ 3094 ] {0f37a4ca-a6b0-4f42-b608-c453345202fd} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'a' in scope SELECT a + 2 AS b FROM test_hm34i6jk.tb. Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308ddd34 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:07.886501 [ 2623 ] {c46be62d-78ba-4607-a3a5-be1e4944ff63} executeQuery: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7fdd5e51e000, frame address: 0x7fdd5e91d920, stack size: 4196064, maximum stack size: 8388608. (TOO_DEEP_RECURSION) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:60148) (comment: 02985_parser_check_stack_size.sh) (in query: create table test (x Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(UInt64))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))) engine=Memory ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, void*&, void const*&, unsigned long&, unsigned long&) @ 0x00000000246ed190 4. ./build_docker/./src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x00000000246ecf9c 5. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034625235 6. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034669950 7. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 8. ./src/Parsers/ParserCreateQuery.h:69: DB::IParserNameTypePair::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346656bf 9. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 10. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 11. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 12. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 13. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserNameTypePairList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034642dfc 14. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 15. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:72: DB::ParserNestedTable::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034641c3d 16. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 17. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034669950 18. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 19. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::(anonymous namespace)::ParserDataTypeArgument::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466b941 20. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 21. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 22. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 23. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 24. ./build_docker/./src/Parsers/ParserDataType.cpp:146: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466a9af 25. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 26. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::(anonymous namespace)::ParserDataTypeArgument::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466b941 27. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 28. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 29. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 30. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 31. ./build_docker/./src/Parsers/ParserDataType.cpp:146: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466a9af 2025.03.05 21:08:07.886963 [ 2623 ] {c46be62d-78ba-4607-a3a5-be1e4944ff63} DynamicQueryHandler: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7fdd5e51e000, frame address: 0x7fdd5e91d920, stack size: 4196064, maximum stack size: 8388608. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, void*&, void const*&, unsigned long&, unsigned long&) @ 0x00000000246ed190 4. ./build_docker/./src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x00000000246ecf9c 5. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034625235 6. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034669950 7. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 8. ./src/Parsers/ParserCreateQuery.h:69: DB::IParserNameTypePair::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346656bf 9. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 10. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 11. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 12. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 13. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserNameTypePairList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034642dfc 14. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 15. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:72: DB::ParserNestedTable::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034641c3d 16. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 17. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034669950 18. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 19. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::(anonymous namespace)::ParserDataTypeArgument::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466b941 20. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 21. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 22. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 23. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 24. ./build_docker/./src/Parsers/ParserDataType.cpp:146: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466a9af 25. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 26. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::(anonymous namespace)::ParserDataTypeArgument::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466b941 27. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 28. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 29. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 30. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 31. ./build_docker/./src/Parsers/ParserDataType.cpp:146: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466a9af (version 24.3.12.76.altinitystable) 2025.03.05 21:08:08.796887 [ 2623 ] {b523a926-9996-4668-94ff-95b499405d8a} executeQuery: Code: 643. DB::Exception: Couldn't open archive '/var/lib/clickhouse/user_files/02994_file_1741205285/test.rar.7z': Unrecognized archive format: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_UNPACK_ARCHIVE) (version 24.3.12.76.altinitystable) (from [::1]:39198) (comment: 02994_libarchive_compression.sh) (in query: SELECT c1 FROM file('02994_file_1741205285/test.rar.7z :: test.csv', CSV);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002904e913 4. ./build_docker/./src/IO/Archives/LibArchiveReader.cpp:0: DB::LibArchiveReader::Handle::openWithPath(String const&) @ 0x000000002f056062 5. ./build_docker/./src/IO/Archives/LibArchiveReader.cpp:43: DB::LibArchiveReader::Handle::Handle(String, bool) @ 0x000000002f05581b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::LibArchiveReader::acquireHandle() @ 0x000000002f052240 7. ./build_docker/./src/IO/Archives/LibArchiveReader.cpp:405: DB::LibArchiveReader::readFile(String const&, bool) @ 0x000000002f052962 8. ./build_docker/./src/Storages/StorageFile.cpp:662: DB::(anonymous namespace)::ReadBufferFromArchiveIterator::next() @ 0x00000000321fa777 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033512ef7 10. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 11. ./build_docker/./src/Storages/StorageFile.cpp:936: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321dd3a1 12. ./build_docker/./src/Storages/StorageFile.cpp:956: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321ddfa1 13. ./build_docker/./src/Storages/StorageFile.cpp:1080: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000321dfc9e 14. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000321e1737 15. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000321e2057 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::StorageFile* std::construct_at[abi:v15000](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e468909 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e46874a 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e4684b4 19. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:88: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e464c29 20. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:08.813206 [ 2623 ] {b523a926-9996-4668-94ff-95b499405d8a} TCPHandler: Code: 643. DB::Exception: Couldn't open archive '/var/lib/clickhouse/user_files/02994_file_1741205285/test.rar.7z': Unrecognized archive format: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_UNPACK_ARCHIVE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, char const*&&) @ 0x000000002904e913 4. ./build_docker/./src/IO/Archives/LibArchiveReader.cpp:0: DB::LibArchiveReader::Handle::openWithPath(String const&) @ 0x000000002f056062 5. ./build_docker/./src/IO/Archives/LibArchiveReader.cpp:43: DB::LibArchiveReader::Handle::Handle(String, bool) @ 0x000000002f05581b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::LibArchiveReader::acquireHandle() @ 0x000000002f052240 7. ./build_docker/./src/IO/Archives/LibArchiveReader.cpp:405: DB::LibArchiveReader::readFile(String const&, bool) @ 0x000000002f052962 8. ./build_docker/./src/Storages/StorageFile.cpp:662: DB::(anonymous namespace)::ReadBufferFromArchiveIterator::next() @ 0x00000000321fa777 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033512ef7 10. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 11. ./build_docker/./src/Storages/StorageFile.cpp:936: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321dd3a1 12. ./build_docker/./src/Storages/StorageFile.cpp:956: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321ddfa1 13. ./build_docker/./src/Storages/StorageFile.cpp:1080: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000321dfc9e 14. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000321e1737 15. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000321e2057 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::StorageFile* std::construct_at[abi:v15000](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e468909 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e46874a 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e4684b4 19. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:88: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e464c29 20. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:09.115835 [ 2623 ] {bac9c478-a416-4cd5-bec1-c307be38df68} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST('[42]', 'Array(LowCardinality(UInt64))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select [42]::Array(LowCardinality(UInt64));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.125694 [ 2623 ] {bac9c478-a416-4cd5-bec1-c307be38df68} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST('[42]', 'Array(LowCardinality(UInt64))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.173212 [ 2623 ] {38ad89be-6984-48bb-a20d-8b4653b6a397} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST('[[[42]]]', 'Array(Array(Array(LowCardinality(UInt64))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select [[[42]]]::Array(Array(Array(LowCardinality(UInt64))));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.177555 [ 2623 ] {38ad89be-6984-48bb-a20d-8b4653b6a397} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST('[[[42]]]', 'Array(Array(Array(LowCardinality(UInt64))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.212084 [ 2623 ] {2776c95d-ea51-456c-95e0-ea518e19210f} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(map('a', 42), 'Map(String, LowCardinality(UInt64))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select map('a', 42)::Map(String, LowCardinality(UInt64));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.217509 [ 2623 ] {2776c95d-ea51-456c-95e0-ea518e19210f} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(map('a', 42), 'Map(String, LowCardinality(UInt64))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.262387 [ 2623 ] {a6cde145-597e-4099-85b4-9c1e41c853f8} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(map('a', map('b', [42])), 'Map(String, Map(String, Array(LowCardinality(UInt64))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select map('a', map('b', [42]))::Map(String, Map(String, Array(LowCardinality(UInt64))));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.266669 [ 2623 ] {a6cde145-597e-4099-85b4-9c1e41c853f8} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(map('a', map('b', [42])), 'Map(String, Map(String, Array(LowCardinality(UInt64))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.387016 [ 2623 ] {990de190-6cbe-492e-a9a2-3d585854324c} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(('a', 42), 'Tuple(String, LowCardinality(UInt64))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select tuple('a', 42)::Tuple(String, LowCardinality(UInt64));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcc34 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.405363 [ 2623 ] {990de190-6cbe-492e-a9a2-3d585854324c} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(('a', 42), 'Tuple(String, LowCardinality(UInt64))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcc34 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.439607 [ 2623 ] {de598a05-3821-473e-9ed8-510911d94657} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(('a', [map('b', 42)]), 'Tuple(String, Array(Map(String, LowCardinality(UInt64))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select tuple('a', [map('b', 42)])::Tuple(String, Array(Map(String, LowCardinality(UInt64))));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:09.445899 [ 2623 ] {de598a05-3821-473e-9ed8-510911d94657} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(('a', [map('b', 42)]), 'Tuple(String, Array(Map(String, LowCardinality(UInt64))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:09.464812 [ 2623 ] {f2dec347-eb88-4ecc-82c9-5c96c45c0eda} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Array(LowCardinality(UInt64))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:09.500309 [ 2623 ] {f2dec347-eb88-4ecc-82c9-5c96c45c0eda} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:09.517007 [ 2623 ] {2f3c7a68-7aa2-44b8-a1ce-36bf2568f8fb} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Array(Array(LowCardinality(UInt64)))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:09.517163 [ 2623 ] {2f3c7a68-7aa2-44b8-a1ce-36bf2568f8fb} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:09.568170 [ 2623 ] {30a1be18-31f3-4a57-bb64-1941bdb939b3} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Map(String, LowCardinality(UInt64))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:09.572838 [ 2623 ] {30a1be18-31f3-4a57-bb64-1941bdb939b3} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:09.585385 [ 2623 ] {fde0cbfd-e789-4523-8808-b6981bdd7f39} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Map(String, Map(String, LowCardinality(UInt64)))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:09.585775 [ 2623 ] {fde0cbfd-e789-4523-8808-b6981bdd7f39} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:09.605563 [ 2623 ] {0578ffb6-e43a-429b-b888-9a0f7f7877e3} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Tuple(String, LowCardinality(UInt64))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcc34 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:09.608800 [ 2623 ] {0578ffb6-e43a-429b-b888-9a0f7f7877e3} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcc34 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:09.655381 [ 2623 ] {48498ac1-ad18-4b94-ab97-229fca0b3676} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Tuple(String, Array(Map(String, LowCardinality(UInt64))))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:09.658493 [ 2623 ] {48498ac1-ad18-4b94-ab97-229fca0b3676} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:09.740433 [ 2623 ] {12ee0792-3b8c-4578-a564-f4d70c2f2ad1} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('[\'42\']', 'Array(FixedString(1000000))'). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select ['42']::Array(FixedString(1000000));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.744239 [ 2623 ] {12ee0792-3b8c-4578-a564-f4d70c2f2ad1} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('[\'42\']', 'Array(FixedString(1000000))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.762074 [ 2623 ] {a13dee25-2b41-42b7-8292-c148980ad7d7} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('[\'42\']', 'Array(FixedString(1000000))'). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select ['42']::Array(FixedString(1000000));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.769671 [ 2623 ] {a13dee25-2b41-42b7-8292-c148980ad7d7} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('[\'42\']', 'Array(FixedString(1000000))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.777253 [ 2623 ] {de97975f-33a6-437d-9eeb-97d55a1e87d4} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('[[[\'42\']]]', 'Array(Array(Array(FixedString(1000000))))'). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select [[['42']]]::Array(Array(Array(FixedString(1000000))));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.777462 [ 2623 ] {de97975f-33a6-437d-9eeb-97d55a1e87d4} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('[[[\'42\']]]', 'Array(Array(Array(FixedString(1000000))))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.837810 [ 2623 ] {112a956e-3d51-4302-bc2c-850be4f29f3b} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(map('a', '42'), 'Map(String, FixedString(1000000))'). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select map('a', '42')::Map(String, FixedString(1000000));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.855031 [ 2623 ] {112a956e-3d51-4302-bc2c-850be4f29f3b} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(map('a', '42'), 'Map(String, FixedString(1000000))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.872936 [ 2623 ] {11271a43-fa92-4d62-9446-b5478d4f495b} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(map('a', map('b', ['42'])), 'Map(String, Map(String, Array(FixedString(1000000))))'). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select map('a', map('b', ['42']))::Map(String, Map(String, Array(FixedString(1000000))));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.873225 [ 2623 ] {11271a43-fa92-4d62-9446-b5478d4f495b} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(map('a', map('b', ['42'])), 'Map(String, Map(String, Array(FixedString(1000000))))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.902361 [ 2623 ] {a12fd19f-be67-4bfd-969e-262f4b699201} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(('a', '42'), 'Tuple(String, FixedString(1000000))'). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select tuple('a', '42')::Tuple(String, FixedString(1000000));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcc34 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.902573 [ 2623 ] {a12fd19f-be67-4bfd-969e-262f4b699201} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(('a', '42'), 'Tuple(String, FixedString(1000000))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcc34 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:09.957015 [ 2623 ] {1e37b94c-94ad-46e1-8849-16d41c0d3178} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(('a', [map('b', '42')]), 'Tuple(String, Array(Map(String, FixedString(1000000))))'). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select tuple('a', [map('b', '42')])::Tuple(String, Array(Map(String, FixedString(1000000))));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:09.957440 [ 2623 ] {1e37b94c-94ad-46e1-8849-16d41c0d3178} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(('a', [map('b', '42')]), 'Tuple(String, Array(Map(String, FixedString(1000000))))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:09.974575 [ 2623 ] {2b728046-63bf-44f5-8f2b-45c8b1caa529} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Array(FixedString(1000000))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:09.978636 [ 2623 ] {2b728046-63bf-44f5-8f2b-45c8b1caa529} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:09.995562 [ 2623 ] {977f823f-6f17-411a-8a88-a4ee9b3ddba2} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Array(Array(FixedString(1000000)))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:09.995900 [ 2623 ] {977f823f-6f17-411a-8a88-a4ee9b3ddba2} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.020513 [ 2623 ] {2c539e0e-8ad9-4193-9ede-deaefa67a078} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Map(String, FixedString(1000000))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.027974 [ 2623 ] {2c539e0e-8ad9-4193-9ede-deaefa67a078} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.029928 [ 2623 ] {a2c96d48-e2c1-4f27-94b7-bbfc2d2bf13b} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Map(String, Map(String, FixedString(1000000)))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.030035 [ 2623 ] {a2c96d48-e2c1-4f27-94b7-bbfc2d2bf13b} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.051272 [ 2623 ] {72f5dcac-c5c4-4b3d-8b5a-1dd232ffbe3c} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Tuple(String, FixedString(1000000))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcc34 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.062853 [ 2623 ] {72f5dcac-c5c4-4b3d-8b5a-1dd232ffbe3c} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcc34 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.081195 [ 2623 ] {4db17019-11da-4ebd-8ab2-79199e62bde2} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Tuple(String, Array(Map(String, FixedString(1000000))))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.105118 [ 2623 ] {4db17019-11da-4ebd-8ab2-79199e62bde2} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.204431 [ 2623 ] {8833acb3-6642-4989-826d-3f0bb8a80d72} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST('[42]', 'Array(Variant(String, UInt64))'). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select [42]::Array(Variant(String, UInt64));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:10.227111 [ 2623 ] {8833acb3-6642-4989-826d-3f0bb8a80d72} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST('[42]', 'Array(Variant(String, UInt64))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:10.229582 [ 2623 ] {4b88c84e-4d5a-41d0-9ae5-6177b4afe983} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST('[[[42]]]', 'Array(Array(Array(Variant(String, UInt64))))'). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select [[[42]]]::Array(Array(Array(Variant(String, UInt64))));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:10.231186 [ 2623 ] {4b88c84e-4d5a-41d0-9ae5-6177b4afe983} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST('[[[42]]]', 'Array(Array(Array(Variant(String, UInt64))))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:10.319076 [ 2623 ] {5ec1a19d-1587-4530-838f-7c5cc5e71ec3} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST(map('a', 42), 'Map(String, Variant(String, UInt64))'). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select map('a', 42)::Map(String, Variant(String, UInt64));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:10.324547 [ 2623 ] {5ec1a19d-1587-4530-838f-7c5cc5e71ec3} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST(map('a', 42), 'Map(String, Variant(String, UInt64))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:10.337206 [ 2623 ] {fcb34586-fa86-423c-aa9e-b51b498f8d0c} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST(map('a', map('b', [42])), 'Map(String, Map(String, Array(Variant(String, UInt64))))'). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select map('a', map('b', [42]))::Map(String, Map(String, Array(Variant(String, UInt64))));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:10.337485 [ 2623 ] {fcb34586-fa86-423c-aa9e-b51b498f8d0c} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST(map('a', map('b', [42])), 'Map(String, Map(String, Array(Variant(String, UInt64))))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:10.376537 [ 2623 ] {a7f1b155-d855-4540-93f1-e522bf961a66} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST(('a', 42), 'Tuple(String, Variant(String, UInt64))'). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select tuple('a', 42)::Tuple(String, Variant(String, UInt64));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcc34 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:10.408435 [ 2623 ] {a7f1b155-d855-4540-93f1-e522bf961a66} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST(('a', 42), 'Tuple(String, Variant(String, UInt64))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcc34 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:10.438202 [ 2623 ] {19455ee4-1960-46e1-ab6e-35a88ee2d5ac} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST(('a', [map('b', 42)]), 'Tuple(String, Array(Map(String, Variant(String, UInt64))))'). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select tuple('a', [map('b', 42)])::Tuple(String, Array(Map(String, Variant(String, UInt64))));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:10.438939 [ 2623 ] {19455ee4-1960-46e1-ab6e-35a88ee2d5ac} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it: In scope SELECT CAST(('a', [map('b', 42)]), 'Tuple(String, Array(Map(String, Variant(String, UInt64))))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:10.471248 [ 2623 ] {c7bcdece-4af4-40d1-ba68-307496ad71ac} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Array(Variant(String, UInt64))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.481653 [ 2623 ] {c7bcdece-4af4-40d1-ba68-307496ad71ac} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.510271 [ 2623 ] {0650af2a-59e9-43bf-9a29-c53b61e2b431} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Array(Array(Variant(String, UInt64)))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.510782 [ 2623 ] {0650af2a-59e9-43bf-9a29-c53b61e2b431} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:75: DB::DataTypeArray::forEachChild(std::function const&) const @ 0x000000002f4597f4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.546980 [ 2623 ] {43ac9ecb-a25d-406e-85fa-8374c50fa704} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Map(String, Variant(String, UInt64))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.547167 [ 2623 ] {43ac9ecb-a25d-406e-85fa-8374c50fa704} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.559164 [ 2623 ] {d93baa55-97a1-4717-b097-57d0929f11f0} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Map(String, Map(String, Variant(String, UInt64)))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.559292 [ 2623 ] {d93baa55-97a1-4717-b097-57d0929f11f0} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.587728 [ 2623 ] {883792eb-4009-4bab-b36d-bebe5fedb2a3} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Tuple(String, Variant(String, UInt64))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcc34 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.587924 [ 2623 ] {883792eb-4009-4bab-b36d-bebe5fedb2a3} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcc34 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.627399 [ 2623 ] {c614b3cd-fd04-49f6-855c-452e6432ba20} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Tuple(String, Array(Map(String, Variant(String, UInt64))))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.627597 [ 2623 ] {c614b3cd-fd04-49f6-855c-452e6432ba20} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because experimental Variant type is not allowed. Set setting allow_experimental_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774ea3 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.663830 [ 2623 ] {1f2389a3-b667-4d69-a707-3200a778dba3} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST('42', 'Variant(String, LowCardinality(UInt64))') SETTINGS allow_experimental_variant_type = 1. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select 42::Variant(String, LowCardinality(UInt64)) settings allow_experimental_variant_type=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x000000002f507554 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:10.666083 [ 2623 ] {1f2389a3-b667-4d69-a707-3200a778dba3} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST('42', 'Variant(String, LowCardinality(UInt64))') SETTINGS allow_experimental_variant_type = 1. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x000000002f507554 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:10.691804 [ 2623 ] {785ed01b-224c-4ca5-bbe2-15215637e5e6} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(('a', [map('b', 42)]), 'Tuple(String, Array(Map(String, Variant(LowCardinality(UInt64), String))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select tuple('a', [map('b', 42)])::Tuple(String, Array(Map(String, Variant(LowCardinality(UInt64), String))));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x000000002f507554 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:10.692015 [ 2623 ] {785ed01b-224c-4ca5-bbe2-15215637e5e6} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(('a', [map('b', 42)]), 'Tuple(String, Array(Map(String, Variant(LowCardinality(UInt64), String))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x000000002f507554 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:10.713598 [ 2623 ] {ab77d18e-a718-4868-a002-8b07e9fb2243} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Variant(LowCardinality(UInt64), String)) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x000000002f507554 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.713785 [ 2623 ] {ab77d18e-a718-4868-a002-8b07e9fb2243} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x000000002f507554 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.732879 [ 2623 ] {8fd575d4-b12a-4f85-a1fb-a3993edcd3cf} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Tuple(String, Array(Map(String, Variant(LowCardinality(UInt64), String))))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x000000002f507554 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.733082 [ 2623 ] {8fd575d4-b12a-4f85-a1fb-a3993edcd3cf} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x000000002f507554 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.761582 [ 2623 ] {7fe38866-0c50-4c52-9e2e-0223b892b4cc} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('42', 'Variant(UInt64, FixedString(1000000))'). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select '42'::Variant(UInt64, FixedString(1000000));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x000000002f507554 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:10.761928 [ 2623 ] {7fe38866-0c50-4c52-9e2e-0223b892b4cc} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('42', 'Variant(UInt64, FixedString(1000000))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x000000002f507554 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:10.787878 [ 2623 ] {08f78341-f767-4217-a5df-f346f9488ef3} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(('a', [map('b', '42')]), 'Tuple(String, Array(Map(String, Variant(UInt32, FixedString(1000000)))))'). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: select tuple('a', [map('b', '42')])::Tuple(String, Array(Map(String, Variant(UInt32, FixedString(1000000)))));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x000000002f507554 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:10.788163 [ 2623 ] {08f78341-f767-4217-a5df-f346f9488ef3} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST(('a', [map('b', '42')]), 'Tuple(String, Array(Map(String, Variant(UInt32, FixedString(1000000)))))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x000000002f507554 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:10.843999 [ 2623 ] {b57eb83a-c0cc-4420-a4de-b8ccacd746fa} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Variant(UInt64, FixedString(1000000))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x000000002f507554 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.844238 [ 2623 ] {b57eb83a-c0cc-4420-a4de-b8ccacd746fa} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DataTypeVariant::forEachChild(std::function const&) const @ 0x000000002f507554 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 7. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.846045 [ 2623 ] {2ba91bc9-ad0e-4443-b842-9bde23d44fda} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:39924) (comment: 02981_nested_bad_types.sql) (in query: create table test (x Tuple(String, Array(Map(String, FixedString(1000000))))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.846145 [ 2623 ] {2ba91bc9-ad0e-4443-b842-9bde23d44fda} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:151: DB::DataTypeMap::forEachChild(std::function const&) const @ 0x000000002f4d6288 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x000000002f4fcca7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003177323b 8. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:10.914843 [ 1579 ] {0c1d0115-9d3a-42d1-a70b-8bb765be06d9} Context: Server has databases (for example `ordinary_test_uwo6mits`) with Ordinary engine, which was deprecated. To convert this database to the new Atomic engine, create a flag /var/lib/clickhouse/flags/convert_ordinary_to_atomic and make sure that ClickHouse has write permission for it. Example: sudo touch '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' && sudo chmod 666 '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' 2025.03.05 21:08:11.209385 [ 3583 ] {588c8176-15db-4af1-b451-efe8b02eeacb} executeQuery: Code: 354. DB::Exception: inflate failed: data error: While reading from: a.tsv: (while reading header): (in file/uri a.tsv): While executing TabSeparatedRowInputFormat: While executing S3. (ZLIB_INFLATE_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:40040) (comment: 02973_s3_compressed_file_in_error_message.sh) (in query: select * from s3('http://localhost:11111/test/a.tsv', TSV, 'x String', 'gzip')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x00000000290a5793 4. ./build_docker/./src/IO/ZlibInflatingReadBuffer.cpp:0: DB::ZlibInflatingReadBuffer::nextImpl() @ 0x00000000290a506a 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x0000000024735e3d 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./src/IO/ReadBuffer.h:106: DB::TabSeparatedFormatReader::checkForSuffix() @ 0x0000000033ab6a72 9. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:137: DB::RowInputFormatWithNamesAndTypes::tryDetectHeader(std::vector>&, std::vector>&) @ 0x00000000336b7187 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x00000000336b5a29 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:103: DB::IRowInputFormat::read() @ 0x0000000033662a38 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Storages/StorageS3.cpp:794: DB::StorageS3Source::generate() @ 0x00000000325b59b4 20. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 21. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 26. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 27. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:11.210198 [ 3583 ] {588c8176-15db-4af1-b451-efe8b02eeacb} TCPHandler: Code: 354. DB::Exception: inflate failed: data error: While reading from: a.tsv: (while reading header): (in file/uri a.tsv): While executing TabSeparatedRowInputFormat: While executing S3. (ZLIB_INFLATE_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x00000000290a5793 4. ./build_docker/./src/IO/ZlibInflatingReadBuffer.cpp:0: DB::ZlibInflatingReadBuffer::nextImpl() @ 0x00000000290a506a 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x0000000024735e3d 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./src/IO/ReadBuffer.h:106: DB::TabSeparatedFormatReader::checkForSuffix() @ 0x0000000033ab6a72 9. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:137: DB::RowInputFormatWithNamesAndTypes::tryDetectHeader(std::vector>&, std::vector>&) @ 0x00000000336b7187 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x00000000336b5a29 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:103: DB::IRowInputFormat::read() @ 0x0000000033662a38 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Storages/StorageS3.cpp:794: DB::StorageS3Source::generate() @ 0x00000000325b59b4 20. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 21. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 26. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 27. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:11.517018 [ 2623 ] {5972d596-11a0-4d3c-bc93-b28c15296028} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE data; to attach existing table or CREATE TABLE data ; to create new table or ATTACH TABLE data FROM '/path/to/data/'
; to create new table and attach data. 2025.03.05 21:08:11.646407 [ 2623 ] {4e2e9775-0206-4da0-9282-7e30d94de3db} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to static storage. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:40086) (comment: 02980_s3_plain_DROP_TABLE_MergeTree.sh) (in query: insert into data values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:2479: DB::StorageMergeTree::assertNotReadonly() const @ 0x000000003307e8c7 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:299: DB::StorageMergeTree::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003307e6bb 6. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 8. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:11.646621 [ 2623 ] {4e2e9775-0206-4da0-9282-7e30d94de3db} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to static storage. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:2479: DB::StorageMergeTree::assertNotReadonly() const @ 0x000000003307e8c7 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:299: DB::StorageMergeTree::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003307e6bb 6. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 8. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:11.664443 [ 2623 ] {39b160be-6199-49de-958f-23bfa0aca736} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to static storage. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:40086) (comment: 02980_s3_plain_DROP_TABLE_MergeTree.sh) (in query: optimize table data final;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:2479: DB::StorageMergeTree::assertNotReadonly() const @ 0x000000003307e8c7 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000330a20ef 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:11.664636 [ 2623 ] {39b160be-6199-49de-958f-23bfa0aca736} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to static storage. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:2479: DB::StorageMergeTree::assertNotReadonly() const @ 0x000000003307e8c7 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000330a20ef 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:12.032812 [ 1579 ] {c6f9a03c-37ab-46b7-a6fd-3c2f2a2e01cb} AsynchronousInsertQueue: Setting 'async_insert_busy_timeout_min_ms'=500 is greater than 'async_insert_busy_timeout_max_ms'=100. Ignoring 'async_insert_busy_timeout_min_ms' 2025.03.05 21:08:12.169644 [ 1579 ] {c67a97bc-b483-453b-8a4d-fa05ab7ce271} executeQuery: Code: 471. DB::Exception: Setting 'async_insert_busy_timeout_increase_rate' must be greater than zero. (INVALID_SETTING_VALUE) (version 24.3.12.76.altinitystable) (from [::1]:40074) (comment: 02968_adaptive_async_insert_timeout.sql) (in query: INSERT INTO async_insert_mt_test SETTINGS async_insert=1, wait_for_async_insert=1, async_insert_busy_timeout_increase_rate=-1.0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:551: DB::AsynchronousInsertQueue::validateSettings(DB::Settings const&, std::shared_ptr) @ 0x000000002fbfb51d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AsynchronousInsertQueue::pushDataChunk(std::shared_ptr, DB::AsynchronousInsertQueue::DataChunk, std::shared_ptr) @ 0x000000002fbf81b2 6. ./contrib/llvm-project/libcxx/include/variant:797: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002fbf7c65 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1053: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fa3cd 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:12.170047 [ 1579 ] {c67a97bc-b483-453b-8a4d-fa05ab7ce271} TCPHandler: Code: 471. DB::Exception: Setting 'async_insert_busy_timeout_increase_rate' must be greater than zero. (INVALID_SETTING_VALUE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:551: DB::AsynchronousInsertQueue::validateSettings(DB::Settings const&, std::shared_ptr) @ 0x000000002fbfb51d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AsynchronousInsertQueue::pushDataChunk(std::shared_ptr, DB::AsynchronousInsertQueue::DataChunk, std::shared_ptr) @ 0x000000002fbf81b2 6. ./contrib/llvm-project/libcxx/include/variant:797: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002fbf7c65 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1053: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fa3cd 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:12.193960 [ 1579 ] {76d2b21e-caee-4f95-af48-09872e0abf75} executeQuery: Code: 471. DB::Exception: Setting 'async_insert_busy_timeout_decrease_rate' must be greater than zero. (INVALID_SETTING_VALUE) (version 24.3.12.76.altinitystable) (from [::1]:40074) (comment: 02968_adaptive_async_insert_timeout.sql) (in query: INSERT INTO async_insert_mt_test SETTINGS async_insert=1, wait_for_async_insert=1, async_insert_busy_timeout_decrease_rate=-1.0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::validateSettings(DB::Settings const&, std::shared_ptr) @ 0x000000002fbfb5b1 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AsynchronousInsertQueue::pushDataChunk(std::shared_ptr, DB::AsynchronousInsertQueue::DataChunk, std::shared_ptr) @ 0x000000002fbf81b2 6. ./contrib/llvm-project/libcxx/include/variant:797: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002fbf7c65 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1053: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fa3cd 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:12.194248 [ 1579 ] {76d2b21e-caee-4f95-af48-09872e0abf75} TCPHandler: Code: 471. DB::Exception: Setting 'async_insert_busy_timeout_decrease_rate' must be greater than zero. (INVALID_SETTING_VALUE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::validateSettings(DB::Settings const&, std::shared_ptr) @ 0x000000002fbfb5b1 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AsynchronousInsertQueue::pushDataChunk(std::shared_ptr, DB::AsynchronousInsertQueue::DataChunk, std::shared_ptr) @ 0x000000002fbf81b2 6. ./contrib/llvm-project/libcxx/include/variant:797: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002fbf7c65 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1053: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fa3cd 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:12.576666 [ 2623 ] {17ca7434-b522-4322-986b-7e6c7a8bc127} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.3.12.76.altinitystable) (from [::1]:40162) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:12.576913 [ 2623 ] {17ca7434-b522-4322-986b-7e6c7a8bc127} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:12.737289 [ 1579 ] {4dd05d20-8aaf-4bf3-8835-372a97d33877} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(topK(4, 2, 'counts'), UInt8) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: topK instead of topK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:40172) (comment: 02966_topk_counts_approx_count_sum.sql) (in query: SELECT topKMerge(4, 3, 'counts')(state) FROM ( SELECT topKState(4, 2, 'counts')(countDigits(number * number)) AS state FROM numbers(1000));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028f70b49 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:12.737554 [ 1579 ] {4dd05d20-8aaf-4bf3-8835-372a97d33877} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(topK(4, 2, 'counts'), UInt8) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: topK instead of topK. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028f70b49 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:12.740234 [ 1579 ] {41e8b46f-23a6-4dbe-9a51-585a2dabc40f} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(topK(4, 2, 'counts'), UInt8) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: topK instead of topK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:40172) (comment: 02966_topk_counts_approx_count_sum.sql) (in query: SELECT topKMerge(4, 2)(state) FROM ( SELECT topKState(4, 2, 'counts')(countDigits(number * number)) AS state FROM numbers(1000));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028f70b49 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:12.740370 [ 1579 ] {41e8b46f-23a6-4dbe-9a51-585a2dabc40f} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(topK(4, 2, 'counts'), UInt8) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: topK instead of topK. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028f70b49 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:12.742486 [ 1579 ] {0c2938d7-1948-4efb-a6ee-2c0ea3618421} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(topK(4, 2, 'counts'), UInt8) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: topK instead of topK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:40172) (comment: 02966_topk_counts_approx_count_sum.sql) (in query: SELECT topKMerge(state) FROM ( SELECT topKState(4, 2, 'counts')(countDigits(number * number)) AS state FROM numbers(1000));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028f70b49 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:12.742655 [ 1579 ] {0c2938d7-1948-4efb-a6ee-2c0ea3618421} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(topK(4, 2, 'counts'), UInt8) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: topK instead of topK. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028f70b49 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:12.825492 [ 2623 ] {407c099d-bc3c-4047-98bf-e218d5f12e1f} executeQuery: Code: 703. DB::Exception: Expected identifier 't.t.t' to contain 1 or 2 parts to be resolved as table expression. In scope system.tables. (INVALID_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:40196) (comment: 02963_invalid_identifier.sql) (in query: SELECT t.t.t.* FROM system.tables WHERE database = currentDatabase();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c851b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::(anonymous namespace)::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308e6cd3 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882ced 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:12.825762 [ 2623 ] {407c099d-bc3c-4047-98bf-e218d5f12e1f} TCPHandler: Code: 703. DB::Exception: Expected identifier 't.t.t' to contain 1 or 2 parts to be resolved as table expression. In scope system.tables. (INVALID_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c851b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::(anonymous namespace)::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308e6cd3 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882ced 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:12.936977 [ 2623 ] {609a6747-c5e4-455c-b50b-b67d455d24e0} executeQuery: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) (version 24.3.12.76.altinitystable) (from [::1]:40208) (comment: 02963_msan_agg_addBatchLookupTable8.sql) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/58727 SELECT number % 2 AS even, aggThrow(number) FROM numbers(10) GROUP BY even;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAggThrow.cpp:0: DB::(anonymous namespace)::AggregateFunctionThrow::create(char*) const @ 0x00000000289f04b9 5. ./build_docker/./src/Interpreters/Aggregator.cpp:837: void DB::Aggregator::createAggregateStates(char*&) const @ 0x000000002feed9a5 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1126: void std::__function::__policy_invoker::__call_impl, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const::'lambda'(char*&), void (char*&)>>(std::__function::__policy_storage const*, char*&) @ 0x0000000030054561 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000289f3c8f 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1117: void DB::Aggregator::executeImplBatch, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x00000000300537ad 9. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000030052648 10. ./build_docker/./src/Interpreters/Aggregator.cpp:984: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002fef4f26 11. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002fe5ae89 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1626: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe6411b 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:12.937241 [ 2623 ] {609a6747-c5e4-455c-b50b-b67d455d24e0} TCPHandler: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAggThrow.cpp:0: DB::(anonymous namespace)::AggregateFunctionThrow::create(char*) const @ 0x00000000289f04b9 5. ./build_docker/./src/Interpreters/Aggregator.cpp:837: void DB::Aggregator::createAggregateStates(char*&) const @ 0x000000002feed9a5 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1126: void std::__function::__policy_invoker::__call_impl, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const::'lambda'(char*&), void (char*&)>>(std::__function::__policy_storage const*, char*&) @ 0x0000000030054561 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000289f3c8f 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1117: void DB::Aggregator::executeImplBatch, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x00000000300537ad 9. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000030052648 10. ./build_docker/./src/Interpreters/Aggregator.cpp:984: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002fef4f26 11. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002fe5ae89 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1626: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe6411b 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:13.250977 [ 1852 ] {97f85219-871f-4043-ba45-08a29ec29bb9} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 27. DB::Exception: Cannot parse input: expected 'true' before: '}': (while reading the value of key x): (at row 1) . (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f696da4 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:876: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f635239 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000337c0bc8 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:137: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef010 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef78b 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000337f0390 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 14. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:171: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x00000000338c085b 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:108: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x00000000338bd238 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:13.251669 [ 2623 ] {97f85219-871f-4043-ba45-08a29ec29bb9} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected 'true' before: '}': (while reading the value of key x): (at row 1) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:40260) (comment: 02961_read_bool_as_string_json.sql) (in query: select * from format(JSONEachRow, 'x String', '{"x" : tru}');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f696da4 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:876: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f635239 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000337c0bc8 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:137: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef010 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef78b 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000337f0390 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 14. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:171: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x00000000338c085b 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:108: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x00000000338bd238 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:13.251873 [ 2623 ] {97f85219-871f-4043-ba45-08a29ec29bb9} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected 'true' before: '}': (while reading the value of key x): (at row 1) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f696da4 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:876: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f635239 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000337c0bc8 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:137: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef010 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef78b 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000337f0390 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 14. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:171: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x00000000338c085b 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:108: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x00000000338bd238 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:13.272870 [ 1610 ] {1234f2f3-bb51-4db6-a31a-8c52ba1d4210} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 27. DB::Exception: Cannot parse input: expected 'false' before: '}': (while reading the value of key x): (at row 1) . (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f696dc3 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:876: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f635239 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000337c0bc8 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:137: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef010 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef78b 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000337f0390 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 14. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:171: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x00000000338c085b 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:108: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x00000000338bd238 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:13.273534 [ 2623 ] {1234f2f3-bb51-4db6-a31a-8c52ba1d4210} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected 'false' before: '}': (while reading the value of key x): (at row 1) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:40260) (comment: 02961_read_bool_as_string_json.sql) (in query: select * from format(JSONEachRow, 'x String', '{"x" : fals}');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f696dc3 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:876: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f635239 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000337c0bc8 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:137: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef010 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef78b 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000337f0390 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 14. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:171: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x00000000338c085b 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:108: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x00000000338bd238 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:13.273679 [ 2623 ] {1234f2f3-bb51-4db6-a31a-8c52ba1d4210} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected 'false' before: '}': (while reading the value of key x): (at row 1) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f696dc3 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:876: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f635239 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000337c0bc8 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:137: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef010 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef78b 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000337f0390 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 14. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:171: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x00000000338c085b 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:108: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x00000000338bd238 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:13.293334 [ 1611 ] {f5af1ed6-3fbe-4929-914d-df193f950838} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 117. DB::Exception: Cannot read JSON field here: 'atru}'. Unexpected symbol 'a': (while reading the value of key x): (at row 1) . (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/IO/ReadHelpers.cpp:0: void DB::skipJSONFieldImpl(DB::ReadBuffer&, StringRef) @ 0x0000000024728c5f 5. ./build_docker/./src/IO/ReadHelpers.cpp:1751: DB::readJSONField(String&, DB::ReadBuffer&) @ 0x000000002470a9a0 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f697809 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:876: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f635239 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000337c0bc8 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:137: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef010 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef78b 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000337f0390 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 14. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:171: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x00000000338c085b 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:108: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x00000000338bd238 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:13.294169 [ 2623 ] {f5af1ed6-3fbe-4929-914d-df193f950838} executeQuery: Code: 117. DB::Exception: Cannot read JSON field here: 'atru}'. Unexpected symbol 'a': (while reading the value of key x): (at row 1) : While executing ParallelParsingBlockInputFormat. (INCORRECT_DATA) (version 24.3.12.76.altinitystable) (from [::1]:40260) (comment: 02961_read_bool_as_string_json.sql) (in query: select * from format(JSONEachRow, 'x String', '{"x" : atru}');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/IO/ReadHelpers.cpp:0: void DB::skipJSONFieldImpl(DB::ReadBuffer&, StringRef) @ 0x0000000024728c5f 5. ./build_docker/./src/IO/ReadHelpers.cpp:1751: DB::readJSONField(String&, DB::ReadBuffer&) @ 0x000000002470a9a0 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f697809 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:876: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f635239 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000337c0bc8 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:137: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef010 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef78b 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000337f0390 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 14. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:171: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x00000000338c085b 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:108: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x00000000338bd238 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:13.294398 [ 2623 ] {f5af1ed6-3fbe-4929-914d-df193f950838} TCPHandler: Code: 117. DB::Exception: Cannot read JSON field here: 'atru}'. Unexpected symbol 'a': (while reading the value of key x): (at row 1) : While executing ParallelParsingBlockInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/IO/ReadHelpers.cpp:0: void DB::skipJSONFieldImpl(DB::ReadBuffer&, StringRef) @ 0x0000000024728c5f 5. ./build_docker/./src/IO/ReadHelpers.cpp:1751: DB::readJSONField(String&, DB::ReadBuffer&) @ 0x000000002470a9a0 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f697809 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:876: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f635239 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000337c0bc8 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:137: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef010 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef78b 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000337f0390 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 14. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:171: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x00000000338c085b 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:108: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x00000000338bd238 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:13.402541 [ 2623 ] {d5694b51-b071-4ea2-b17c-d123f71775be} executeQuery: Code: 691. DB::Exception: Unknown element 'goodbye' for enum. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.3.12.76.altinitystable) (from [::1]:40274) (comment: 02958_transform_enum.sql) (in query: WITH arrayJoin(['Hello', 'world'])::Enum('Hello', 'world') AS x SELECT x, transform(x, ['Hello', 'world', 'goodbye'], [123, 456], 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/DataTypes/EnumValues.cpp:0: DB::EnumValues<_BitInt(8)>::getValue(StringRef, bool) const @ 0x000000002f538d3c 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createStringToEnumWrapper>() const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000184f1f95 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000031693477 12. ./build_docker/./src/Interpreters/castColumn.cpp:46: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000316929e1 13. DB::(anonymous namespace)::FunctionTransform::initialize(std::vector> const&, std::shared_ptr const&) const @ 0x0000000021ba8b17 14. ./contrib/llvm-project/libcxx/include/__threading_support:304: std::__call_once(unsigned long volatile&, void*, void (*)(void*)) @ 0x0000000038a434d3 15. DB::(anonymous namespace)::FunctionTransform::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021b41b5b 16. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 17. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 18. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 20. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 22. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 23. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 25. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 26. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:08:13.402817 [ 2623 ] {d5694b51-b071-4ea2-b17c-d123f71775be} TCPHandler: Code: 691. DB::Exception: Unknown element 'goodbye' for enum. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/DataTypes/EnumValues.cpp:0: DB::EnumValues<_BitInt(8)>::getValue(StringRef, bool) const @ 0x000000002f538d3c 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createStringToEnumWrapper>() const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000184f1f95 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000031693477 12. ./build_docker/./src/Interpreters/castColumn.cpp:46: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000316929e1 13. DB::(anonymous namespace)::FunctionTransform::initialize(std::vector> const&, std::shared_ptr const&) const @ 0x0000000021ba8b17 14. ./contrib/llvm-project/libcxx/include/__threading_support:304: std::__call_once(unsigned long volatile&, void*, void (*)(void*)) @ 0x0000000038a434d3 15. DB::(anonymous namespace)::FunctionTransform::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021b41b5b 16. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 17. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 18. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 20. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 22. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 23. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 25. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 26. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:08:13.893064 [ 2623 ] {36dd8d15-b92a-487c-a074-f7b0e566d228} executeQuery: Code: 277. DB::Exception: Primary key (i) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:40312) (comment: 02950_part_offset_as_primary_key.sql) (in query: -- the force_primary_key check still works select i from a where _part_offset = 4 order by i settings force_primary_key = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1623: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f415d8 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:13.893301 [ 2623 ] {36dd8d15-b92a-487c-a074-f7b0e566d228} TCPHandler: Code: 277. DB::Exception: Primary key (i) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1623: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f415d8 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:13.897044 [ 2623 ] {832d71ec-3619-45c6-9f0a-e5b84bed20fc} executeQuery: Code: 277. DB::Exception: Primary key (i) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:40312) (comment: 02950_part_offset_as_primary_key.sql) (in query: -- combining with other primary keys doesn't work (makes no sense) select i from a where i = -3 or _part_offset = 4 order by i settings force_primary_key = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1623: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f415d8 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:13.897156 [ 2623 ] {832d71ec-3619-45c6-9f0a-e5b84bed20fc} TCPHandler: Code: 277. DB::Exception: Primary key (i) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1623: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f415d8 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:15.125133 [ 1655 ] {c2b6407b-c337-4e09-9fa7-b5deb50af955} executeQuery: Code: 701. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. (CLUSTER_DOESNT_EXIST) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:42044) (comment: 02947_parallel_replicas_remote.sql) (in query: SELECT count() AS `count()`, sum(`__table1`.`id`) AS `sum(id)` FROM `test_i8gbo40p`.`test` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:377: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>) @ 0x00000000318f3306 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003307da5a 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:15.132290 [ 1655 ] {c2b6407b-c337-4e09-9fa7-b5deb50af955} TCPHandler: Code: 701. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. (CLUSTER_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:377: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>) @ 0x00000000318f3306 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003307da5a 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:15.146725 [ 2623 ] {e2e69f6b-074b-4f45-a757-63f9e1bb1983} executeQuery: Code: 701. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:377: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>) @ 0x00000000318f3306 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003307da5a 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 : While executing Remote. (CLUSTER_DOESNT_EXIST) (version 24.3.12.76.altinitystable) (from [::1]:40368) (comment: 02947_parallel_replicas_remote.sql) (in query: SELECT count(), sum(id) FROM remote('127.0.0.1|127.0.0.2|127.0.0.3|127.0.0.4', currentDatabase(), test) SETTINGS allow_experimental_parallel_reading_from_replicas = 2, max_parallel_replicas = 4, prefer_localhost_replica = 0, parallel_replicas_for_non_replicated_merge_tree = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:08:15.147373 [ 2623 ] {e2e69f6b-074b-4f45-a757-63f9e1bb1983} TCPHandler: Code: 701. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:377: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>) @ 0x00000000318f3306 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003307da5a 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 : While executing Remote. (CLUSTER_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:08:15.191848 [ 1655 ] {20bb7a14-fb77-4b73-b382-799654b5196c} executeQuery: Code: 561. DB::Exception: ZSTD stream decoding failed: error 'Frame requires too much memory for decoding'; ZSTD version: 1.5.5: While reading from: /var/lib/clickhouse/user_files/test_02961_1741205294315323.csv: (while reading header): (in file/uri /var/lib/clickhouse/user_files/test_02961_1741205294315323.csv): While executing CSVRowInputFormat: While executing File. (ZSTD_DECODER_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:40376) (comment: 02961_output_format_compress_params.sh) (in query: SELECT count() FROM file('test_02961_1741205294315323.csv', 'CSV', 'x UInt64', 'zstd') SETTINGS zstd_window_log_max = 29;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, char const (&) [6], String&&) @ 0x000000002473f3bf 4. ./build_docker/./src/IO/ZstdInflatingReadBuffer.cpp:0: DB::ZstdInflatingReadBuffer::nextImpl() @ 0x000000002473ee16 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x0000000024735e3d 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./src/IO/ReadHelpers.h:1832: DB::skipBOMIfExists(DB::ReadBuffer&) @ 0x00000000336c0912 9. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:79: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x00000000336b545d 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:103: DB::IRowInputFormat::read() @ 0x0000000033662a38 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 12. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 16. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 18. ./build_docker/./src/Storages/StorageFile.cpp:1431: DB::StorageFileSource::generate() @ 0x00000000321e9cc0 19. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 20. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:15.192512 [ 1655 ] {20bb7a14-fb77-4b73-b382-799654b5196c} TCPHandler: Code: 561. DB::Exception: ZSTD stream decoding failed: error 'Frame requires too much memory for decoding'; ZSTD version: 1.5.5: While reading from: /var/lib/clickhouse/user_files/test_02961_1741205294315323.csv: (while reading header): (in file/uri /var/lib/clickhouse/user_files/test_02961_1741205294315323.csv): While executing CSVRowInputFormat: While executing File. (ZSTD_DECODER_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, char const (&) [6], String&&) @ 0x000000002473f3bf 4. ./build_docker/./src/IO/ZstdInflatingReadBuffer.cpp:0: DB::ZstdInflatingReadBuffer::nextImpl() @ 0x000000002473ee16 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x0000000024735e3d 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./src/IO/ReadHelpers.h:1832: DB::skipBOMIfExists(DB::ReadBuffer&) @ 0x00000000336c0912 9. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:79: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x00000000336b545d 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:103: DB::IRowInputFormat::read() @ 0x0000000033662a38 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 12. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 16. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 18. ./build_docker/./src/Storages/StorageFile.cpp:1431: DB::StorageFileSource::generate() @ 0x00000000321e9cc0 19. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 20. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:15.573821 [ 731 ] {52a8b509-3bff-45fa-b931-a9f0b9df89ed} executeQuery: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:34792) (comment: 02946_parallel_replicas_force_primary_key.sql) (in query: SELECT `__table1`.`k` AS `k`, count() AS `count()` FROM `test_0xskoq4c`.`t1` AS `__table1` GROUP BY `__table1`.`k` ORDER BY `__table1`.`k` ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1623: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f415d8 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:15.573838 [ 1579 ] {3e31e70e-303a-45a4-8e70-85b6ae2e191d} executeQuery: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:47666) (comment: 02946_parallel_replicas_force_primary_key.sql) (in query: SELECT `__table1`.`k` AS `k`, count() AS `count()` FROM `test_0xskoq4c`.`t1` AS `__table1` GROUP BY `__table1`.`k` ORDER BY `__table1`.`k` ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1623: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f415d8 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:15.573978 [ 3583 ] {bf9419aa-1ac7-4737-ad28-833c9dca96fa} executeQuery: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:42058) (comment: 02946_parallel_replicas_force_primary_key.sql) (in query: SELECT `__table1`.`k` AS `k`, count() AS `count()` FROM `test_0xskoq4c`.`t1` AS `__table1` GROUP BY `__table1`.`k` ORDER BY `__table1`.`k` ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1623: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f415d8 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:15.574021 [ 1579 ] {3e31e70e-303a-45a4-8e70-85b6ae2e191d} TCPHandler: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1623: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f415d8 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:15.573988 [ 731 ] {52a8b509-3bff-45fa-b931-a9f0b9df89ed} TCPHandler: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1623: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f415d8 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:15.574122 [ 3583 ] {bf9419aa-1ac7-4737-ad28-833c9dca96fa} TCPHandler: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1623: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f415d8 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:15.585711 [ 3510 ] {b936216b-1598-4a90-b39a-f4c47e73d461} executeQuery: Code: 277. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1623: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f415d8 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 : While executing Remote. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:40386) (comment: 02946_parallel_replicas_force_primary_key.sql) (in query: -- parallel replicas, primary key is NOT used SELECT k, count() FROM t1 GROUP BY k ORDER BY k SETTINGS force_primary_key = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000332f12c6 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f44cb3b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:08:15.586402 [ 3510 ] {b936216b-1598-4a90-b39a-f4c47e73d461} TCPHandler: Code: 277. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1623: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f415d8 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 : While executing Remote. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000332f12c6 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f44cb3b 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:08:15.758120 [ 731 ] {184b5e90-a3f3-4541-8c7f-f78deb2e8505} executeQuery: Code: 497. DB::Exception: test_m1e1daaf_test_user_02947: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(a) ON test_m1e1daaf.t_merge_tree_index. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:40470) (comment: 02947_merge_tree_index_table_3.sh) (in query: SELECT a FROM t_merge_tree_index), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:126: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104cf5b 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:15.758420 [ 731 ] {184b5e90-a3f3-4541-8c7f-f78deb2e8505} TCPHandler: Code: 497. DB::Exception: test_m1e1daaf_test_user_02947: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(a) ON test_m1e1daaf.t_merge_tree_index. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:126: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104cf5b 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:15.979158 [ 3510 ] {7d1bb671-30c0-4624-a197-167f2dd690b3} executeQuery: Code: 497. DB::Exception: test_m1e1daaf_test_user_02947: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(arr) ON test_m1e1daaf.t_merge_tree_index. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:40512) (comment: 02947_merge_tree_index_table_3.sh) (in query: SELECT arr FROM t_merge_tree_index), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:126: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104cf5b 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:15.979401 [ 3510 ] {7d1bb671-30c0-4624-a197-167f2dd690b3} TCPHandler: Code: 497. DB::Exception: test_m1e1daaf_test_user_02947: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(arr) ON test_m1e1daaf.t_merge_tree_index. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:126: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104cf5b 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:16.171807 [ 5338 ] {93afa463-84c9-40b0-b343-95a4d3506a5e} executeQuery: Code: 497. DB::Exception: test_m1e1daaf_test_user_02947: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(`arr.size0`) ON test_m1e1daaf.t_merge_tree_index. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:40550) (comment: 02947_merge_tree_index_table_3.sh) (in query: SELECT arr.size0 FROM t_merge_tree_index), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:126: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104cf5b 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:16.172070 [ 5338 ] {93afa463-84c9-40b0-b343-95a4d3506a5e} TCPHandler: Code: 497. DB::Exception: test_m1e1daaf_test_user_02947: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(`arr.size0`) ON test_m1e1daaf.t_merge_tree_index. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:126: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104cf5b 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:16.595165 [ 3522 ] {227d1f77-e70a-43a1-959b-7898d0769fcb} executeQuery: Code: 497. DB::Exception: test_m1e1daaf_test_user_02947: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(a) ON test_m1e1daaf.t_merge_tree_index. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:40588) (comment: 02947_merge_tree_index_table_3.sh) (in query: SELECT a FROM mergeTreeIndex(currentDatabase(), t_merge_tree_index, with_marks = true)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTreeIndex::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000323463b1 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:16.595717 [ 3522 ] {227d1f77-e70a-43a1-959b-7898d0769fcb} TCPHandler: Code: 497. DB::Exception: test_m1e1daaf_test_user_02947: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(a) ON test_m1e1daaf.t_merge_tree_index. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTreeIndex::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000323463b1 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:16.675554 [ 3510 ] {923b1235-3de5-4685-ba0c-6a2bb179cb26} executeQuery: Code: 70. DB::Exception: Cannot convert type UInt32 to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: While processing CAST(CAST('42', 'UInt32'), 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:40594) (comment: 02942_variant_cast.sql) (in query: select 42::UInt32::Variant(String, UInt64);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e2ed 5. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002fb5db0b 7. ./build_docker/./src/Interpreters/ActionsDAG.cpp:244: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002fb5d0e3 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:645: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe2f05d 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe439bf 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe33cd5 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe3ce75 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002fe1eecd 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, std::shared_ptr&, bool) @ 0x000000002fddf8d7 14. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000002fdf2a6d 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2071: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000002fdfa383 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1059: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7e037 17. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f6287d 18. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 19. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 21. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:08:16.675849 [ 3510 ] {923b1235-3de5-4685-ba0c-6a2bb179cb26} TCPHandler: Code: 70. DB::Exception: Cannot convert type UInt32 to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: While processing CAST(CAST('42', 'UInt32'), 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e2ed 5. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002fb5db0b 7. ./build_docker/./src/Interpreters/ActionsDAG.cpp:244: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002fb5d0e3 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:645: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe2f05d 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe439bf 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe33cd5 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe3ce75 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002fe1eecd 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, std::shared_ptr&, bool) @ 0x000000002fddf8d7 14. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000002fdf2a6d 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2071: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000002fdfa383 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1059: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7e037 17. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f6287d 18. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 19. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 21. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:08:16.685893 [ 3510 ] {f9bfabf6-23de-4217-907e-b3ee3036236f} executeQuery: Code: 70. DB::Exception: Cannot convert type DateTime to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: While processing CAST(now(), 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:40594) (comment: 02942_variant_cast.sql) (in query: select now()::Variant(String, UInt64);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e2ed 5. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002fb5db0b 7. ./build_docker/./src/Interpreters/ActionsDAG.cpp:244: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002fb5d0e3 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:645: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe2f05d 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe439bf 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe33cd5 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe3ce75 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002fe1eecd 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, std::shared_ptr&, bool) @ 0x000000002fddf8d7 14. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000002fdf2a6d 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2071: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000002fdfa383 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1059: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7e037 17. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f6287d 18. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 19. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 21. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:08:16.686022 [ 3510 ] {f9bfabf6-23de-4217-907e-b3ee3036236f} TCPHandler: Code: 70. DB::Exception: Cannot convert type DateTime to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: While processing CAST(now(), 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e2ed 5. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002fb5db0b 7. ./build_docker/./src/Interpreters/ActionsDAG.cpp:244: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002fb5d0e3 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:645: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe2f05d 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe439bf 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe33cd5 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe3ce75 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002fe1eecd 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, std::shared_ptr&, bool) @ 0x000000002fddf8d7 14. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000002fdf2a6d 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2071: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000002fdfa383 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1059: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7e037 17. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f6287d 18. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 19. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 21. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:08:16.775057 [ 3510 ] {4ca13cdf-2881-4e6c-8795-f7c97bc7b8ca} executeQuery: Code: 6. DB::Exception: Cannot parse string 'str' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: While processing CAST(CAST('str', 'Variant(String, UInt64)'), 'UInt64'). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:40594) (comment: 02942_variant_cast.sql) (in query: select 'str'::Variant(String, UInt64)::UInt64;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182e9b67 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182e12ef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001825163d 14. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 15. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 18. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 20. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002fb5de8b 22. ./build_docker/./src/Interpreters/ActionsDAG.cpp:244: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002fb5d0e3 23. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:645: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe2f05d 24. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe439bf 25. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe33cd5 26. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe3ce75 27. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002fe1eecd 28. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, std::shared_ptr&, bool) @ 0x000000002fddf8d7 29. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000002fdf2a6d 30. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2071: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000002fdfa383 31. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1059: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7e037 2025.03.05 21:08:16.775275 [ 3510 ] {4ca13cdf-2881-4e6c-8795-f7c97bc7b8ca} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'str' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: While processing CAST(CAST('str', 'Variant(String, UInt64)'), 'UInt64'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182e9b67 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182e12ef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001825163d 14. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 15. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 18. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 20. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002fb5de8b 22. ./build_docker/./src/Interpreters/ActionsDAG.cpp:244: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002fb5d0e3 23. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:645: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe2f05d 24. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe439bf 25. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe33cd5 26. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe3ce75 27. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002fe1eecd 28. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, std::shared_ptr&, bool) @ 0x000000002fddf8d7 29. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000002fdf2a6d 30. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2071: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000002fdfa383 31. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1059: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7e037 2025.03.05 21:08:16.802992 [ 3522 ] {a41b9aca-7434-44fc-8fd1-07a799834c77} executeQuery: Code: 497. DB::Exception: test_m1e1daaf_test_user_02947: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(a) ON test_m1e1daaf.t_merge_tree_index. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:40606) (comment: 02947_merge_tree_index_table_3.sh) (in query: SELECT a.mark FROM mergeTreeIndex(currentDatabase(), t_merge_tree_index, with_marks = true)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTreeIndex::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000323463b1 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:16.803271 [ 3522 ] {a41b9aca-7434-44fc-8fd1-07a799834c77} TCPHandler: Code: 497. DB::Exception: test_m1e1daaf_test_user_02947: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(a) ON test_m1e1daaf.t_merge_tree_index. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTreeIndex::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000323463b1 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:16.840610 [ 3510 ] {6103521e-0876-4596-88d6-716baa04e638} executeQuery: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION CAST(multiIf(equals(number, 1), CAST(NULL, 'Variant(String, UInt64)'), equals(number, 2), CAST('Hello', 'Variant(String, UInt64)'), CAST(number, 'Variant(String, UInt64)')) :: 4, 'UInt64' :: 6) -> CAST(multiIf(equals(number, 1), CAST(NULL, 'Variant(String, UInt64)'), equals(number, 2), CAST('Hello', 'Variant(String, UInt64)'), CAST(number, 'Variant(String, UInt64)')), 'UInt64') UInt64 : 1'. (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:40594) (comment: 02942_variant_cast.sql) (in query: select CAST(multiIf(number == 1, NULL::Variant(String, UInt64), number == 2, 'Hello'::Variant(String, UInt64), number::Variant(String, UInt64)), 'UInt64') from numbers(6);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182e9b67 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182e12ef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001825163d 14. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 17. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:16.840845 [ 3510 ] {6103521e-0876-4596-88d6-716baa04e638} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION CAST(multiIf(equals(number, 1), CAST(NULL, 'Variant(String, UInt64)'), equals(number, 2), CAST('Hello', 'Variant(String, UInt64)'), CAST(number, 'Variant(String, UInt64)')) :: 4, 'UInt64' :: 6) -> CAST(multiIf(equals(number, 1), CAST(NULL, 'Variant(String, UInt64)'), equals(number, 2), CAST('Hello', 'Variant(String, UInt64)'), CAST(number, 'Variant(String, UInt64)')), 'UInt64') UInt64 : 1'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182e9b67 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182e12ef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001825163d 14. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 17. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:16.890897 [ 3510 ] {f53ae9bc-a89d-4aae-9762-574162f95aaf} executeQuery: Code: 70. DB::Exception: Cannot convert type Variant(String, UInt64) to Variant(Array(UInt64), String). Conversion between Variant types is allowed only when new Variant type is an extension of an initial one: While processing CAST(CAST('str', 'Variant(String, UInt64)'), 'Variant(String, Array(UInt64))'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:40594) (comment: 02942_variant_cast.sql) (in query: select 'str'::Variant(String, UInt64)::Variant(String, Array(UInt64));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824d90b 5. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002fb5db0b 7. ./build_docker/./src/Interpreters/ActionsDAG.cpp:244: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002fb5d0e3 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:645: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe2f05d 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe439bf 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe33cd5 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe3ce75 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002fe1eecd 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, std::shared_ptr&, bool) @ 0x000000002fddf8d7 14. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000002fdf2a6d 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2071: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000002fdfa383 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1059: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7e037 17. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f6287d 18. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 19. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 21. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:08:16.891135 [ 3510 ] {f53ae9bc-a89d-4aae-9762-574162f95aaf} TCPHandler: Code: 70. DB::Exception: Cannot convert type Variant(String, UInt64) to Variant(Array(UInt64), String). Conversion between Variant types is allowed only when new Variant type is an extension of an initial one: While processing CAST(CAST('str', 'Variant(String, UInt64)'), 'Variant(String, Array(UInt64))'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824d90b 5. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002fb5db0b 7. ./build_docker/./src/Interpreters/ActionsDAG.cpp:244: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002fb5d0e3 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:645: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe2f05d 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe439bf 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe33cd5 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe3ce75 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002fe1eecd 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, std::shared_ptr&, bool) @ 0x000000002fddf8d7 14. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000002fdf2a6d 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2071: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000002fdfa383 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1059: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7e037 17. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f6287d 18. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 19. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 21. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:08:17.057583 [ 3510 ] {f92afd62-e60e-431e-9f07-d93feb6f46e1} executeQuery: Code: 497. DB::Exception: test_m1e1daaf_test_user_02947: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(arr) ON test_m1e1daaf.t_merge_tree_index. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:40620) (comment: 02947_merge_tree_index_table_3.sh) (in query: SELECT arr.mark FROM mergeTreeIndex(currentDatabase(), t_merge_tree_index, with_marks = true)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTreeIndex::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000323463b1 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:17.057970 [ 3510 ] {f92afd62-e60e-431e-9f07-d93feb6f46e1} TCPHandler: Code: 497. DB::Exception: test_m1e1daaf_test_user_02947: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(arr) ON test_m1e1daaf.t_merge_tree_index. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTreeIndex::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000323463b1 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:17.271802 [ 3510 ] {fcb8ea01-ec9b-49e5-a6e5-da4672c9ac63} executeQuery: Code: 497. DB::Exception: test_m1e1daaf_test_user_02947: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(`arr.size0`) ON test_m1e1daaf.t_merge_tree_index. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:40658) (comment: 02947_merge_tree_index_table_3.sh) (in query: SELECT arr.size0.mark FROM mergeTreeIndex(currentDatabase(), t_merge_tree_index, with_marks = true)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTreeIndex::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000323463b1 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:17.272165 [ 3510 ] {fcb8ea01-ec9b-49e5-a6e5-da4672c9ac63} TCPHandler: Code: 497. DB::Exception: test_m1e1daaf_test_user_02947: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(`arr.size0`) ON test_m1e1daaf.t_merge_tree_index. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTreeIndex::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000323463b1 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:18.448366 [ 1579 ] {c622213f-28c3-4785-ae2d-9ae438eaa618} executeQuery: Code: 36. DB::Exception: dateTrunc doesn't support nanosecond: In scope SELECT dateTrunc('Nanosecond', toDate('2022-03-01')). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40840) (comment: 02935_date_trunc_case_unsensitiveness.sql) (in query: SELECT dateTrunc('Nanosecond', toDate('2022-03-01'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. DB::(anonymous namespace)::FunctionDateTrunc::getReturnTypeImpl(std::vector> const&) const::'lambda'()::operator()() const @ 0x000000001aa8fe7e 5. DB::(anonymous namespace)::FunctionDateTrunc::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa8ee83 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:18.448596 [ 1579 ] {c622213f-28c3-4785-ae2d-9ae438eaa618} TCPHandler: Code: 36. DB::Exception: dateTrunc doesn't support nanosecond: In scope SELECT dateTrunc('Nanosecond', toDate('2022-03-01')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. DB::(anonymous namespace)::FunctionDateTrunc::getReturnTypeImpl(std::vector> const&) const::'lambda'()::operator()() const @ 0x000000001aa8fe7e 5. DB::(anonymous namespace)::FunctionDateTrunc::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa8ee83 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:18.451367 [ 1579 ] {b2526ee9-ac27-4294-ad01-d13e821c1f84} executeQuery: Code: 36. DB::Exception: dateTrunc doesn't support microsecond: In scope SELECT dateTrunc('MicroSecond', toDate('2022-03-01')). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40840) (comment: 02935_date_trunc_case_unsensitiveness.sql) (in query: SELECT dateTrunc('MicroSecond', toDate('2022-03-01'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. DB::(anonymous namespace)::FunctionDateTrunc::getReturnTypeImpl(std::vector> const&) const::'lambda'()::operator()() const @ 0x000000001aa8fe7e 5. DB::(anonymous namespace)::FunctionDateTrunc::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa8ee83 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:18.451516 [ 1579 ] {b2526ee9-ac27-4294-ad01-d13e821c1f84} TCPHandler: Code: 36. DB::Exception: dateTrunc doesn't support microsecond: In scope SELECT dateTrunc('MicroSecond', toDate('2022-03-01')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. DB::(anonymous namespace)::FunctionDateTrunc::getReturnTypeImpl(std::vector> const&) const::'lambda'()::operator()() const @ 0x000000001aa8fe7e 5. DB::(anonymous namespace)::FunctionDateTrunc::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa8ee83 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:18.453011 [ 1579 ] {fb28324d-cba1-4399-bb3e-1d32fd8f9abf} executeQuery: Code: 36. DB::Exception: dateTrunc doesn't support millisecond: In scope SELECT dateTrunc('MILLISECOND', toDate('2022-03-01')). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40840) (comment: 02935_date_trunc_case_unsensitiveness.sql) (in query: SELECT dateTrunc('MILLISECOND', toDate('2022-03-01'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. DB::(anonymous namespace)::FunctionDateTrunc::getReturnTypeImpl(std::vector> const&) const::'lambda'()::operator()() const @ 0x000000001aa8fe7e 5. DB::(anonymous namespace)::FunctionDateTrunc::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa8ee83 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:18.453123 [ 1579 ] {fb28324d-cba1-4399-bb3e-1d32fd8f9abf} TCPHandler: Code: 36. DB::Exception: dateTrunc doesn't support millisecond: In scope SELECT dateTrunc('MILLISECOND', toDate('2022-03-01')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. DB::(anonymous namespace)::FunctionDateTrunc::getReturnTypeImpl(std::vector> const&) const::'lambda'()::operator()() const @ 0x000000001aa8fe7e 5. DB::(anonymous namespace)::FunctionDateTrunc::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa8ee83 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:18.588635 [ 3522 ] {bf4fe2ed-0553-45e3-a7de-4bb92ddd0aca} executeQuery: Code: 701. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. (CLUSTER_DOESNT_EXIST) (version 24.3.12.76.altinitystable) (from [::1]:40874) (comment: 02935_parallel_replicas_settings.sql) (in query: SELECT count() FROM test_parallel_replicas_settings WHERE NOT ignore(*);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:377: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>) @ 0x00000000318f3306 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003307da5a 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:18.588822 [ 3522 ] {bf4fe2ed-0553-45e3-a7de-4bb92ddd0aca} TCPHandler: Code: 701. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. (CLUSTER_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:377: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>) @ 0x00000000318f3306 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003307da5a 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:18.715391 [ 731 ] {ec9b4f02-2c3d-4b2a-b7a4-1db84f6cc7b4} executeQuery: Code: 290. DB::Exception: Maximum limit of 3 projection(s) exceeded. (LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:40930) (comment: 02934_merge_tree_max_projections.sql) (in query: ALTER TABLE test_max_mt_projections_alter ADD PROJECTION p4 (SELECT c2, c3 ORDER BY c2, c3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception const&>(int, FormatStringHelperImpl const&>::type>, DB::SettingFieldNumber const&) @ 0x000000002fca749b 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:678: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af1206 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3410: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40c96 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:18.715575 [ 731 ] {ec9b4f02-2c3d-4b2a-b7a4-1db84f6cc7b4} TCPHandler: Code: 290. DB::Exception: Maximum limit of 3 projection(s) exceeded. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception const&>(int, FormatStringHelperImpl const&>::type>, DB::SettingFieldNumber const&) @ 0x000000002fca749b 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:678: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af1206 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3410: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40c96 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:18.773336 [ 731 ] {90503177-cc44-4026-b2d4-ec3b0a1fd56b} executeQuery: Code: 290. DB::Exception: Maximum limit of 1 projection(s) exceeded. (LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:40930) (comment: 02934_merge_tree_max_projections.sql) (in query: CREATE TABLE test_max_mt_projections_create (`c1` UInt32, `c2` UInt32, PROJECTION p1 (SELECT c1, c2 ORDER BY c2), PROJECTION p2 (SELECT c2 ORDER BY c2)) ENGINE = MergeTree ORDER BY c1 SETTINGS max_projections = 1, index_granularity = 63503, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.47342032194137573, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 449383995, compact_parts_max_granules_to_buffer = 210, compact_parts_merge_max_bytes_to_prefetch_part = 18776496, merge_max_block_size = 22778, old_parts_lifetime = 30., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 1546623, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 91841, primary_key_compress_block_size = 44373), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception const&>(int, FormatStringHelperImpl const&>::type>, DB::SettingFieldNumber const&) @ 0x000000002fca749b 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:678: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af1206 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 11. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:18.773580 [ 731 ] {90503177-cc44-4026-b2d4-ec3b0a1fd56b} TCPHandler: Code: 290. DB::Exception: Maximum limit of 1 projection(s) exceeded. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception const&>(int, FormatStringHelperImpl const&>::type>, DB::SettingFieldNumber const&) @ 0x000000002fca749b 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:678: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af1206 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 11. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:18.779661 [ 731 ] {f3d5dc4f-da26-46aa-85ed-442b6926fe5a} executeQuery: Code: 290. DB::Exception: Maximum limit of 0 projection(s) exceeded. (LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:40930) (comment: 02934_merge_tree_max_projections.sql) (in query: CREATE TABLE test_max_mt_projections_create (`c1` UInt32, `c2` UInt32, PROJECTION p (SELECT c1, c2 ORDER BY c2)) ENGINE = MergeTree ORDER BY c1 SETTINGS max_projections = 0, index_granularity = 63503, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.47342032194137573, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 449383995, compact_parts_max_granules_to_buffer = 210, compact_parts_merge_max_bytes_to_prefetch_part = 18776496, merge_max_block_size = 22778, old_parts_lifetime = 30., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 1546623, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 91841, primary_key_compress_block_size = 44373), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception const&>(int, FormatStringHelperImpl const&>::type>, DB::SettingFieldNumber const&) @ 0x000000002fca749b 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:678: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af1206 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 11. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:18.779830 [ 731 ] {f3d5dc4f-da26-46aa-85ed-442b6926fe5a} TCPHandler: Code: 290. DB::Exception: Maximum limit of 0 projection(s) exceeded. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception const&>(int, FormatStringHelperImpl const&>::type>, DB::SettingFieldNumber const&) @ 0x000000002fca749b 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:678: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af1206 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 11. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:18.794388 [ 731 ] {b21ddf5c-b742-4d11-8934-b97fbfc6af58} executeQuery: Code: 290. DB::Exception: Maximum limit of 1 projection(s) exceeded. (LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:40930) (comment: 02934_merge_tree_max_projections.sql) (in query: ALTER TABLE test_max_mt_projections_create ADD PROJECTION p2 (SELECT c2 ORDER BY c2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception const&>(int, FormatStringHelperImpl const&>::type>, DB::SettingFieldNumber const&) @ 0x000000002fca749b 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:678: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af1206 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3410: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40c96 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:18.794566 [ 731 ] {b21ddf5c-b742-4d11-8934-b97fbfc6af58} TCPHandler: Code: 290. DB::Exception: Maximum limit of 1 projection(s) exceeded. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception const&>(int, FormatStringHelperImpl const&>::type>, DB::SettingFieldNumber const&) @ 0x000000002fca749b 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:678: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af1206 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3410: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40c96 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:19.634945 [ 3522 ] {2b85e223-5a3a-4e74-b035-6b81f38be21e} executeQueryWithParallelReplicas: Setting 'use_hedged_requests' explicitly with enabled 'allow_experimental_parallel_reading_from_replicas' has no effect. Hedged connections are not used for parallel reading from replicas 2025.03.05 21:08:20.190193 [ 3522 ] {b76d6be6-86c6-43a7-b08b-da2ca045d555} executeQuery: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different values of constants in column 'a': actual: 1, expected: 3. (AMBIGUOUS_COLUMN_NAME) (version 24.3.12.76.altinitystable) (from [::1]:59114) (comment: 02933_paste_join.sql) (in query: SELECT * FROM (SELECT 1 AS a) PASTE JOIN (SELECT 2 AS b) PASTE JOIN (SELECT 3 AS a) SETTINGS allow_experimental_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x000000002f119dc9 4. ./build_docker/./src/Core/Block.cpp:38: void DB::onError>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x000000002f114af1 5. ./build_docker/./src/Core/Block.cpp:38: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000002f10ae2a 6. ./contrib/llvm-project/libcxx/include/vector:1595: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000002f10b124 7. ./build_docker/./src/Interpreters/ExpressionActions.cpp:778: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdba263 8. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 10. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:20.190499 [ 3522 ] {b76d6be6-86c6-43a7-b08b-da2ca045d555} TCPHandler: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different values of constants in column 'a': actual: 1, expected: 3. (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x000000002f119dc9 4. ./build_docker/./src/Core/Block.cpp:38: void DB::onError>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x000000002f114af1 5. ./build_docker/./src/Core/Block.cpp:38: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000002f10ae2a 6. ./contrib/llvm-project/libcxx/include/vector:1595: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000002f10b124 7. ./build_docker/./src/Interpreters/ExpressionActions.cpp:778: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdba263 8. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 10. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:20.247813 [ 3522 ] {60f6148a-16f5-4493-a03c-1042330491d3} executeQuery: Code: 179. DB::Exception: Multiple table expressions with same alias test2.a. In scope SELECT * FROM test1 AS `test2.a` PASTE JOIN test2 AS `test2.a`. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 24.3.12.76.altinitystable) (from [::1]:59114) (comment: 02933_paste_join.sql) (in query: SELECT * FROM test1 `test2.a` PASTE JOIN test2 `test2.a`;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr&) @ 0x000000003088fbc1 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr&) @ 0x000000003088f774 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8158: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e6a1 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:20.248012 [ 3522 ] {60f6148a-16f5-4493-a03c-1042330491d3} TCPHandler: Code: 179. DB::Exception: Multiple table expressions with same alias test2.a. In scope SELECT * FROM test1 AS `test2.a` PASTE JOIN test2 AS `test2.a`. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr&) @ 0x000000003088fbc1 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr&) @ 0x000000003088f774 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8158: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e6a1 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:20.268618 [ 3522 ] {7b0bfcd9-ef4f-416b-9bec-db8d7842efed} executeQuery: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: a Int32 Int32(size = 0) a UInt64 UInt64(size = 0). (AMBIGUOUS_COLUMN_NAME) (version 24.3.12.76.altinitystable) (from [::1]:59114) (comment: 02933_paste_join.sql) (in query: SELECT * FROM test1 PASTE JOIN (SELECT number AS a FROM numbers(2) ORDER BY number DESC);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002f119af1 4. ./build_docker/./src/Core/Block.cpp:38: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000002f10a4e6 5. ./contrib/llvm-project/libcxx/include/vector:1595: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000002f10b124 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65ee9 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 9. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000031013b4f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:20.268842 [ 3522 ] {7b0bfcd9-ef4f-416b-9bec-db8d7842efed} TCPHandler: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: a Int32 Int32(size = 0) a UInt64 UInt64(size = 0). (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002f119af1 4. ./build_docker/./src/Core/Block.cpp:38: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000002f10a4e6 5. ./contrib/llvm-project/libcxx/include/vector:1595: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000002f10b124 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65ee9 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 9. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000031013b4f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:28.695026 [ 3510 ] {efe56975-7ec8-4e2e-be80-8c58b0e705b9} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(any, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:60306) (comment: 02922_respect_nulls_states.sql) (in query: SELECT first_value_respect_nullsMerge(t) FROM (Select first_valueState(number) as t from numbers(1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028f70b49 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:28.695173 [ 3510 ] {efe56975-7ec8-4e2e-be80-8c58b0e705b9} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(any, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028f70b49 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:28.697359 [ 3510 ] {d367dd86-5a7a-45b9-bd83-f3656cde6808} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(anyLast_respect_nulls, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: anyLast_respect_nulls instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:60306) (comment: 02922_respect_nulls_states.sql) (in query: SELECT first_value_respect_nullsMerge(t) FROM (Select last_value_respect_nullsState(number) as t from numbers(1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028f70b49 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:28.697495 [ 3510 ] {d367dd86-5a7a-45b9-bd83-f3656cde6808} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(anyLast_respect_nulls, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: anyLast_respect_nulls instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028f70b49 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:28.699750 [ 3510 ] {f1eca4ca-98be-4e99-8dba-75086d3daf08} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(any_respect_nulls, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any_respect_nulls instead of anyLast_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:60306) (comment: 02922_respect_nulls_states.sql) (in query: SELECT last_value_respect_nullsMerge(t) FROM (Select first_value_respect_nullsState(number) as t from numbers(1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028f70b49 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:28.699923 [ 3510 ] {f1eca4ca-98be-4e99-8dba-75086d3daf08} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(any_respect_nulls, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any_respect_nulls instead of anyLast_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028f70b49 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:28.702055 [ 3510 ] {8622d497-1069-40fd-a129-78e41feaa686} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(any, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:60306) (comment: 02922_respect_nulls_states.sql) (in query: SELECT first_value_respect_nullsMerge(CAST(unhex('00'), 'AggregateFunction(any, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028f70b49 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:28.702198 [ 3510 ] {8622d497-1069-40fd-a129-78e41feaa686} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(any, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028f70b49 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:28.729178 [ 3510 ] {ef3bf926-eb20-4253-b779-8774b26bb9b1} executeQuery: Code: 117. DB::Exception: Incorrect type (0) in any_respect_nullsState: In scope SELECT first_value_respect_nullsMerge(CAST(unhex('00'), 'AggregateFunction(any_respect_nulls, UInt64)')). (INCORRECT_DATA) (version 24.3.12.76.altinitystable) (from [::1]:60306) (comment: 02922_respect_nulls_states.sql) (in query: -- Invalid (starts at 1) SELECT first_value_respect_nullsMerge(CAST(unhex('00'), 'AggregateFunction(any_respect_nulls, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception<_BitInt(8), std::basic_string, std::basic_string::allocator>>(int, FormatStringHelperImpl::type, std::basic_string::type_identity, std::basic_string::allocator>>::type>, std::basic_string::type_identity<_BitInt(8)>&&, std::basic_string::type_identity, std::basic_string::allocator>>&&) @ 0x0000000026e41b3b 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnyRespectNulls.cpp:0: DB::(anonymous namespace)::AggregateFunctionAnyRespectNulls::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026e36f72 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 7. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:08:28.729364 [ 3510 ] {ef3bf926-eb20-4253-b779-8774b26bb9b1} TCPHandler: Code: 117. DB::Exception: Incorrect type (0) in any_respect_nullsState: In scope SELECT first_value_respect_nullsMerge(CAST(unhex('00'), 'AggregateFunction(any_respect_nulls, UInt64)')). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception<_BitInt(8), std::basic_string, std::basic_string::allocator>>(int, FormatStringHelperImpl::type, std::basic_string::type_identity, std::basic_string::allocator>>::type>, std::basic_string::type_identity<_BitInt(8)>&&, std::basic_string::type_identity, std::basic_string::allocator>>&&) @ 0x0000000026e41b3b 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnyRespectNulls.cpp:0: DB::(anonymous namespace)::AggregateFunctionAnyRespectNulls::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026e36f72 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 7. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:08:28.762750 [ 3510 ] {ede527b4-c1fc-416b-83ec-cf788bbed73b} executeQuery: Code: 117. DB::Exception: Incorrect type (NULL) in non-nullable any_respect_nullsState: In scope SELECT first_value_respect_nullsMerge(CAST(unhex('02'), 'AggregateFunction(any_respect_nulls, UInt64)')). (INCORRECT_DATA) (version 24.3.12.76.altinitystable) (from [::1]:60306) (comment: 02922_respect_nulls_states.sql) (in query: -- Set to NULL SELECT first_value_respect_nullsMerge(CAST(unhex('02'), 'AggregateFunction(any_respect_nulls, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnyRespectNulls.cpp:0: DB::(anonymous namespace)::AggregateFunctionAnyRespectNulls::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026e3671b 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 7. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:08:28.763005 [ 3510 ] {ede527b4-c1fc-416b-83ec-cf788bbed73b} TCPHandler: Code: 117. DB::Exception: Incorrect type (NULL) in non-nullable any_respect_nullsState: In scope SELECT first_value_respect_nullsMerge(CAST(unhex('02'), 'AggregateFunction(any_respect_nulls, UInt64)')). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnyRespectNulls.cpp:0: DB::(anonymous namespace)::AggregateFunctionAnyRespectNulls::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026e3671b 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 7. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:08:28.808823 [ 3510 ] {cbab1788-1d9e-4026-869b-2e19e621b461} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 8.: In scope SELECT first_value_respect_nullsMerge(CAST(unhex('03'), 'AggregateFunction(any_respect_nulls, UInt64)')). (CANNOT_READ_ALL_DATA) (version 24.3.12.76.altinitystable) (from [::1]:60306) (comment: 02922_respect_nulls_states.sql) (in query: -- Set to other value, but without providing value SELECT first_value_respect_nullsMerge(CAST(unhex('03'), 'AggregateFunction(any_respect_nulls, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000187cb1aa 5. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:181: DB::SerializationNumber::deserializeBinary(DB::Field&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f64e5ee 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnyRespectNulls.cpp:0: DB::(anonymous namespace)::AggregateFunctionAnyRespectNulls::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026e36e58 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 15. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 17. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 19. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 22. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 25. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:28.809273 [ 3510 ] {cbab1788-1d9e-4026-869b-2e19e621b461} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 8.: In scope SELECT first_value_respect_nullsMerge(CAST(unhex('03'), 'AggregateFunction(any_respect_nulls, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000187cb1aa 5. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:181: DB::SerializationNumber::deserializeBinary(DB::Field&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f64e5ee 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnyRespectNulls.cpp:0: DB::(anonymous namespace)::AggregateFunctionAnyRespectNulls::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026e36e58 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 15. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 17. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 19. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 22. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 25. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:29.063913 [ 3522 ] {84c6daf5-350c-4557-8a3d-93fb106b7784} executeQuery: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:45158) (comment: 02921_database_filesystem_path_check.sql) (in query: create database db_filesystem ENGINE=Filesystem('/etc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x000000002f702ed4 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::DatabaseFilesystem* std::construct_at[abi:v15000]&, DB::DatabaseFilesystem*>(DB::DatabaseFilesystem*, String const&, String&, std::shared_ptr&) @ 0x000000002f70c5d8 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&>(std::allocator, String const&, String&, std::shared_ptr&) @ 0x000000002f70c3e6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, String&, std::shared_ptr&, void>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x000000002f70c14c 8. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002f707676 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f6ff6cd 10. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f6fe614 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:291: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000307a8c2f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000307d565a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:29.064118 [ 3522 ] {84c6daf5-350c-4557-8a3d-93fb106b7784} TCPHandler: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x000000002f702ed4 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::DatabaseFilesystem* std::construct_at[abi:v15000]&, DB::DatabaseFilesystem*>(DB::DatabaseFilesystem*, String const&, String&, std::shared_ptr&) @ 0x000000002f70c5d8 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&>(std::allocator, String const&, String&, std::shared_ptr&) @ 0x000000002f70c3e6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, String&, std::shared_ptr&, void>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x000000002f70c14c 8. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002f707676 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f6ff6cd 10. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f6fe614 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:291: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000307a8c2f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000307d565a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:29.080033 [ 3522 ] {778265e0-1b96-44af-9a03-ff0b90a4cbe7} executeQuery: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:45158) (comment: 02921_database_filesystem_path_check.sql) (in query: create database db_filesystem ENGINE=Filesystem('../../../../../../../../etc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x000000002f702ed4 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::DatabaseFilesystem* std::construct_at[abi:v15000]&, DB::DatabaseFilesystem*>(DB::DatabaseFilesystem*, String const&, String&, std::shared_ptr&) @ 0x000000002f70c5d8 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&>(std::allocator, String const&, String&, std::shared_ptr&) @ 0x000000002f70c3e6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, String&, std::shared_ptr&, void>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x000000002f70c14c 8. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002f707676 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f6ff6cd 10. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f6fe614 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:291: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000307a8c2f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000307d565a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:29.080202 [ 3522 ] {778265e0-1b96-44af-9a03-ff0b90a4cbe7} TCPHandler: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x000000002f702ed4 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::DatabaseFilesystem* std::construct_at[abi:v15000]&, DB::DatabaseFilesystem*>(DB::DatabaseFilesystem*, String const&, String&, std::shared_ptr&) @ 0x000000002f70c5d8 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&>(std::allocator, String const&, String&, std::shared_ptr&) @ 0x000000002f70c3e6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, String&, std::shared_ptr&, void>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x000000002f70c14c 8. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002f707676 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f6ff6cd 10. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f6fe614 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:291: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000307a8c2f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000307d565a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:30.249763 [ 3510 ] {1cc88e67-84f6-4d1e-be73-2ed2a4a10117} executeQuery: Code: 36. DB::Exception: 'StorageFuzzJSON' supports only columns of String type, got Nullable(Int64). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:45334) (comment: 02919_storage_fuzzjson.sql) (in query: CREATE TABLE 02919_test_table_invalid_col_type ( str Nullable(Int64) ) ENGINE = FuzzJSON('{"pet":"rat"}', NULL);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageFuzzJSON.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003222325e 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:30.249964 [ 3510 ] {1cc88e67-84f6-4d1e-be73-2ed2a4a10117} TCPHandler: Code: 36. DB::Exception: 'StorageFuzzJSON' supports only columns of String type, got Nullable(Int64). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageFuzzJSON.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003222325e 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:30.364577 [ 1579 ] {dea1d802-d71e-4985-bcd0-8fcffc8b29a1} executeQuery: Code: 137. DB::Exception: test_ss6swyb1.id_value_dictionary: unknown dictionary source type: clickhousex. (UNKNOWN_ELEMENT_IN_CONFIG) (version 24.3.12.76.altinitystable) (from [::1]:45376) (comment: 02918_wrong_dictionary_source.sql) (in query: -- There is no "CLICKHOUSEX" dictionary source, so the next query must fail even if `dictionaries_lazy_load` is enabled. CREATE DICTIONARY id_value_dictionary(id UInt64, value String) PRIMARY KEY id SOURCE(CLICKHOUSEX(TABLE 'source_table')) LIFETIME(MIN 0 MAX 1000) LAYOUT(FLAT());), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Dictionaries/DictionarySourceFactory.cpp:116: DB::DictionarySourceFactory::checkSourceAvailable(String const&, String const&, std::shared_ptr const&) const @ 0x000000002e834a6d 5. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x000000002f6e5975 6. ./build_docker/./src/Storages/StorageDictionary.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000032182bce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:30.364869 [ 1579 ] {dea1d802-d71e-4985-bcd0-8fcffc8b29a1} TCPHandler: Code: 137. DB::Exception: test_ss6swyb1.id_value_dictionary: unknown dictionary source type: clickhousex. (UNKNOWN_ELEMENT_IN_CONFIG), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Dictionaries/DictionarySourceFactory.cpp:116: DB::DictionarySourceFactory::checkSourceAvailable(String const&, String const&, std::shared_ptr const&) const @ 0x000000002e834a6d 5. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x000000002f6e5975 6. ./build_docker/./src/Storages/StorageDictionary.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000032182bce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:31.836867 [ 1579 ] {dbe8177c-45fb-408d-93b3-c1a6850cb242} executeQuery: Code: 481. DB::Exception: SQLite database file path '/etc/passwd' must be inside 'user_files' directory. (PATH_ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:45514) (comment: 02918_sqlite_path_check.sh) (in query: Select * from sqlite('/etc/passwd', 'something');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:22: DB::processSQLiteError(String const&, bool) @ 0x000000002e91dba7 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateSQLiteDatabasePath(String const&, String const&, bool, bool) @ 0x000000002e91e666 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::openSQLiteDB(String const&, std::shared_ptr, bool) @ 0x000000002e91eab3 7. ./build_docker/./src/TableFunctions/TableFunctionSQLite.cpp:91: DB::(anonymous namespace)::TableFunctionSQLite::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4e8c98 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:31.840750 [ 1579 ] {dbe8177c-45fb-408d-93b3-c1a6850cb242} TCPHandler: Code: 481. DB::Exception: SQLite database file path '/etc/passwd' must be inside 'user_files' directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:22: DB::processSQLiteError(String const&, bool) @ 0x000000002e91dba7 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateSQLiteDatabasePath(String const&, String const&, bool, bool) @ 0x000000002e91e666 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::openSQLiteDB(String const&, std::shared_ptr, bool) @ 0x000000002e91eab3 7. ./build_docker/./src/TableFunctions/TableFunctionSQLite.cpp:91: DB::(anonymous namespace)::TableFunctionSQLite::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4e8c98 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:32.056772 [ 3522 ] {c89a7420-bd47-4047-ac5a-59cae7aeda29} executeQuery: Code: 481. DB::Exception: SQLite database file path '../../../../etc/passwd' must be inside 'user_files' directory. (PATH_ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:45544) (comment: 02918_sqlite_path_check.sh) (in query: Select * from sqlite('../../../../etc/passwd', 'something');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:22: DB::processSQLiteError(String const&, bool) @ 0x000000002e91dba7 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateSQLiteDatabasePath(String const&, String const&, bool, bool) @ 0x000000002e91e666 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::openSQLiteDB(String const&, std::shared_ptr, bool) @ 0x000000002e91eab3 7. ./build_docker/./src/TableFunctions/TableFunctionSQLite.cpp:91: DB::(anonymous namespace)::TableFunctionSQLite::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4e8c98 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:32.057062 [ 3522 ] {c89a7420-bd47-4047-ac5a-59cae7aeda29} TCPHandler: Code: 481. DB::Exception: SQLite database file path '../../../../etc/passwd' must be inside 'user_files' directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:22: DB::processSQLiteError(String const&, bool) @ 0x000000002e91dba7 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateSQLiteDatabasePath(String const&, String const&, bool, bool) @ 0x000000002e91e666 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::openSQLiteDB(String const&, std::shared_ptr, bool) @ 0x000000002e91eab3 7. ./build_docker/./src/TableFunctions/TableFunctionSQLite.cpp:91: DB::(anonymous namespace)::TableFunctionSQLite::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4e8c98 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:32.337011 [ 1579 ] {e6416657-f0b6-442e-8ec8-c4c2aa207c9f} executeQuery: Code: 38. DB::Exception: Cannot parse date here: abcdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', 'abcdefgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.337325 [ 1579 ] {e6416657-f0b6-442e-8ec8-c4c2aa207c9f} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: abcdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.340235 [ 1579 ] {8b7a2d6a-74e5-4deb-bf4d-e6782dab67d5} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2bcdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2bcdefgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.340394 [ 1579 ] {8b7a2d6a-74e5-4deb-bf4d-e6782dab67d5} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2bcdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.342485 [ 1579 ] {40539fc6-ff39-40d4-9aca-7a41490350ff} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 20cdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '20cdefgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.342654 [ 1579 ] {40539fc6-ff39-40d4-9aca-7a41490350ff} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 20cdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.344779 [ 1579 ] {c455ceff-3352-4259-904c-90e826e2f4d7} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 202defgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '202defgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.344931 [ 1579 ] {c455ceff-3352-4259-904c-90e826e2f4d7} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 202defgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.346847 [ 1579 ] {51e939d0-f7d6-4ae2-a988-71030a4d2754} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020efgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020efgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.346999 [ 1579 ] {51e939d0-f7d6-4ae2-a988-71030a4d2754} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020efgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.348947 [ 1579 ] {a10be4eb-7da3-4cd0-8a5b-28beb583f703} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 20200fgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '20200fgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.349097 [ 1579 ] {a10be4eb-7da3-4cd0-8a5b-28beb583f703} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 20200fgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.351030 [ 1579 ] {80834616-d424-4c45-a847-bb778c672951} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 202001gh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '202001gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.351274 [ 1579 ] {80834616-d424-4c45-a847-bb778c672951} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 202001gh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.353569 [ 1579 ] {ce36a731-a9d4-49a6-bc22-eaef8c3be2be} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020010h,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020010h,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.353841 [ 1579 ] {ce36a731-a9d4-49a6-bc22-eaef8c3be2be} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020010h,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.388707 [ 1579 ] {4df9c5a3-5c86-4c4f-b485-19b44b143648} executeQuery: Code: 38. DB::Exception: Cannot parse date here: abcd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', 'abcd-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.388853 [ 1579 ] {4df9c5a3-5c86-4c4f-b485-19b44b143648} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: abcd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.390503 [ 1579 ] {b806c2b9-23f1-425a-9c98-5f554271d251} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2bcd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2bcd-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.390641 [ 1579 ] {b806c2b9-23f1-425a-9c98-5f554271d251} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2bcd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.392131 [ 1579 ] {228dd333-8492-4f8d-b26d-5b3c5c2a4c6a} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 20cd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '20cd-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.392244 [ 1579 ] {228dd333-8492-4f8d-b26d-5b3c5c2a4c6a} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 20cd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.393735 [ 1579 ] {65d5098d-1f6a-4df3-b643-49fd7ffe563b} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 202d-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '202d-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.393843 [ 1579 ] {65d5098d-1f6a-4df3-b643-49fd7ffe563b} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 202d-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.395264 [ 1579 ] {4628ea8f-4ab0-4c3e-b4f5-1684237ae94b} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.395370 [ 1579 ] {4628ea8f-4ab0-4c3e-b4f5-1684237ae94b} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.396822 [ 1579 ] {74c48917-fddc-4aab-920d-7bae67e02e77} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-f-gh,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020-f-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.396928 [ 1579 ] {74c48917-fddc-4aab-920d-7bae67e02e77} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-f-gh,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.398300 [ 1579 ] {f2aa5b26-5bbd-4952-a372-a8e6187c5e4a} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-f-g,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020-f-g,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.398401 [ 1579 ] {f2aa5b26-5bbd-4952-a372-a8e6187c5e4a} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-f-g,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.399832 [ 1579 ] {ab34ae32-edda-42a7-9ed3-b0550a6fd3ba} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-0f-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020-0f-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.399934 [ 1579 ] {ab34ae32-edda-42a7-9ed3-b0550a6fd3ba} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-0f-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.401364 [ 1579 ] {93d86102-83f0-4bb6-bdb0-301b0c0e13f1} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-01-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020-01-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.401466 [ 1579 ] {93d86102-83f0-4bb6-bdb0-301b0c0e13f1} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-01-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.403232 [ 1579 ] {507f1b0c-bb8f-4a71-ab41-8522e8a10ddb} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-01-h,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020-01-h,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.403447 [ 1579 ] {507f1b0c-bb8f-4a71-ab41-8522e8a10ddb} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-01-h,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.405256 [ 1579 ] {5df55baa-54bb-4860-a363-69105e0e7aad} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-1-gh,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020-1-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.405358 [ 1579 ] {5df55baa-54bb-4860-a363-69105e0e7aad} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-1-gh,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.406781 [ 1579 ] {28e60077-a569-4aed-85a1-0e9518ca2bda} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-1-h,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:45580) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020-1-h,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.406883 [ 1579 ] {28e60077-a569-4aed-85a1-0e9518ca2bda} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-1-h,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002f5cc980 7. ./src/Common/assert_cast.h:50: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cc2bf 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 13. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 22. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:08:32.496097 [ 1579 ] {17ba25d9-13c0-4151-b9ba-40fc601f4eaf} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_06v0ka8c.Mapping (087159f8-d7a4-4564-9457-6823bb347c21), because some tables depend on it: test_06v0ka8c.Sub_distributed. (HAVE_DEPENDENT_OBJECTS) (version 24.3.12.76.altinitystable) (from [::1]:45608) (comment: 02916_joinget_dependency.sh) (in query: DROP TABLE Mapping; ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000002fda7392 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1456: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9b344 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9ba54 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000307f634b 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:103: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000307f3e26 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000307f29e2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:32.496523 [ 1579 ] {17ba25d9-13c0-4151-b9ba-40fc601f4eaf} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_06v0ka8c.Mapping (087159f8-d7a4-4564-9457-6823bb347c21), because some tables depend on it: test_06v0ka8c.Sub_distributed. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000002fda7392 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1456: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9b344 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9ba54 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000307f634b 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:103: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000307f3e26 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000307f29e2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:32.745795 [ 1579 ] {7f813967-34bf-493c-8fca-c1279055acb2} executeQuery: Code: 497. DB::Exception: user_02916_dictionary_access_test_kcmb4lby: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON _table_function.dictionary. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:45662) (comment: 02916_dictionary_access.sh) (in query: SELECT * FROM dictionary(dict_02916_dictionary_access_test_kcmb4lby);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed6f18b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002ed6dbe3 6. ./build_docker/./src/Access/ContextAccess.cpp:726: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002ed2b09a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002fc97417 8. ./build_docker/./src/Interpreters/Context.cpp:1403: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002fc4e4a5 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::TableFunctionDictionary::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4ec8c6 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:32.746159 [ 1579 ] {7f813967-34bf-493c-8fca-c1279055acb2} TCPHandler: Code: 497. DB::Exception: user_02916_dictionary_access_test_kcmb4lby: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON _table_function.dictionary. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed6f18b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002ed6dbe3 6. ./build_docker/./src/Access/ContextAccess.cpp:726: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002ed2b09a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002fc97417 8. ./build_docker/./src/Interpreters/Context.cpp:1403: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002fc4e4a5 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::TableFunctionDictionary::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4ec8c6 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:32.990039 [ 5754 ] {825476a0-cca7-4583-8fbb-161fcb63741b} executeQuery: Code: 497. DB::Exception: user_02916_dictionary_access_test_kcmb4lby: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_kcmb4lby.dict_02916_dictionary_access_test_kcmb4lby: In scope SELECT dictGet(dict_02916_dictionary_access_test_kcmb4lby, 'value', 1). (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:45708) (comment: 02916_dictionary_access.sh) (in query: SELECT dictGet(dict_02916_dictionary_access_test_kcmb4lby, 'value', 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed6f18b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002ed6dbe3 6. ./build_docker/./src/Access/ContextAccess.cpp:726: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002ed2b09a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002fc97417 8. ./build_docker/./src/Interpreters/Context.cpp:1403: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002fc4e4a5 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000018813cba 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001880f625 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 15. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 17. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 19. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 22. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 28. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 30. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 2025.03.05 21:08:32.990441 [ 5754 ] {825476a0-cca7-4583-8fbb-161fcb63741b} TCPHandler: Code: 497. DB::Exception: user_02916_dictionary_access_test_kcmb4lby: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_kcmb4lby.dict_02916_dictionary_access_test_kcmb4lby: In scope SELECT dictGet(dict_02916_dictionary_access_test_kcmb4lby, 'value', 1). (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed6f18b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002ed6dbe3 6. ./build_docker/./src/Access/ContextAccess.cpp:726: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002ed2b09a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002fc97417 8. ./build_docker/./src/Interpreters/Context.cpp:1403: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002fc4e4a5 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000018813cba 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001880f625 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 15. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 17. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 19. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 22. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 28. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 30. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 2025.03.05 21:08:33.623999 [ 3510 ] {d7b7aa46-16aa-49c1-aa26-828e1ffbf709} DynamicQueryHandler: Code: 271. DB::Exception: Cannot decompress, the number of elements in the compressed data (65) is not equal to the expected number of elements in the decompressed data (1). (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018820822 4. ./build_docker/./src/Compression/CompressionCodecT64.cpp:0: DB::CompressionCodecT64::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x000000002f3a9379 5. ./build_docker/./src/Compression/ICompressionCodec.cpp:110: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x000000002f3d6095 6. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:0: DB::CompressedReadBuffer::nextImpl() @ 0x000000002f377e0e 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc149b4 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x00000000317022e2 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 14. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:36.338161 [ 5999 ] {8ffb7f37-3f5c-4296-8382-4eeaa981c6a1} StorageMaterializedView: Inner table does not exist, will not backup any data 2025.03.05 21:08:36.591299 [ 5863 ] {020fe7cf-6d09-4ecb-85dc-937c92f79f5c} executeQuery: Code: 117. DB::Exception: Projection non_existing_projection is specified in setting force_optimize_projection_name but not used. (INCORRECT_DATA) (version 24.3.12.76.altinitystable) (from [::1]:46130) (comment: 02906_force_optimize_projection_name.sql) (in query: SELECT name FROM test GROUP BY name SETTINGS force_optimize_projection_name='non_existing_projection';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1263: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fb6e1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:36.591786 [ 5863 ] {020fe7cf-6d09-4ecb-85dc-937c92f79f5c} TCPHandler: Code: 117. DB::Exception: Projection non_existing_projection is specified in setting force_optimize_projection_name but not used. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1263: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fb6e1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:36.594768 [ 5863 ] {a8efaf8d-598c-4b06-b505-7385a05cc250} executeQuery: Code: 117. DB::Exception: Projection projection_name is specified in setting force_optimize_projection_name but not used. (INCORRECT_DATA) (version 24.3.12.76.altinitystable) (from [::1]:46130) (comment: 02906_force_optimize_projection_name.sql) (in query: SELECT name FROM test SETTINGS force_optimize_projection_name='projection_name';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1263: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fb6e1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:36.594945 [ 5863 ] {a8efaf8d-598c-4b06-b505-7385a05cc250} TCPHandler: Code: 117. DB::Exception: Projection projection_name is specified in setting force_optimize_projection_name but not used. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1263: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fb6e1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:36.742785 [ 3510 ] {044262ab-30c9-41af-abbb-e77b8f8f0efe} executeQuery: Code: 386. DB::Exception: There is no supertype for types IntervalDay, IntervalMonth: In scope SELECT toIntervalDay(30) < toIntervalMonth(1). (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:46156) (comment: 02906_interval_comparison.sql) (in query: -- It is reasonable to not give an answer for this: SELECT INTERVAL 30 DAY < INTERVAL 1 MONTH;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f58974c 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:618: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ea30 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001dd68b4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dd47611 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:08:36.742978 [ 3510 ] {044262ab-30c9-41af-abbb-e77b8f8f0efe} TCPHandler: Code: 386. DB::Exception: There is no supertype for types IntervalDay, IntervalMonth: In scope SELECT toIntervalDay(30) < toIntervalMonth(1). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f58974c 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:618: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ea30 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001dd68b4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dd47611 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:08:36.772524 [ 3510 ] {b34c1b22-b099-4342-a716-d203948c5a37} executeQuery: Code: 386. DB::Exception: There is no supertype for types IntervalSecond, IntervalYear: In scope SELECT toIntervalSecond(1) = toIntervalYear(1). (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:46156) (comment: 02906_interval_comparison.sql) (in query: -- This we could change in the future: SELECT INTERVAL 1 SECOND = INTERVAL 1 YEAR;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f58974c 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:618: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ea30 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001b1a5b4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b184411 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:08:36.772817 [ 3510 ] {b34c1b22-b099-4342-a716-d203948c5a37} TCPHandler: Code: 386. DB::Exception: There is no supertype for types IntervalSecond, IntervalYear: In scope SELECT toIntervalSecond(1) = toIntervalYear(1). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f58974c 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:618: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ea30 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001b1a5b4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b184411 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:08:36.801971 [ 3510 ] {c1600792-7746-42b0-b8c7-de3addab0786} executeQuery: Code: 386. DB::Exception: There is no supertype for types IntervalSecond, IntervalYear: In scope SELECT toIntervalSecond(1) <= toIntervalYear(1). (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:46156) (comment: 02906_interval_comparison.sql) (in query: SELECT INTERVAL 1 SECOND <= INTERVAL 1 YEAR;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f58974c 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:618: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ea30 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001e3a548a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e383f31 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:08:36.802183 [ 3510 ] {c1600792-7746-42b0-b8c7-de3addab0786} TCPHandler: Code: 386. DB::Exception: There is no supertype for types IntervalSecond, IntervalYear: In scope SELECT toIntervalSecond(1) <= toIntervalYear(1). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f58974c 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:618: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ea30 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001e3a548a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e383f31 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:08:38.393220 [ 5338 ] {cbf2512f-5a49-4241-a376-b38eeeef042a} executeQuery: Code: 81. DB::Exception: Database test_h7rxa48p_02911_keeper_map does not exist. (UNKNOWN_DATABASE) (version 24.3.12.76.altinitystable) (from [::1]:46246) (comment: 02911_backup_restore_keeper_map.sh) (in query: SELECT count() FROM test_h7rxa48p_02911_keeper_map.02911_backup_restore_keeper_map1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a6bd 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x00000000308a1073 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089c809 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6962: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086fd78 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:38.393507 [ 5338 ] {cbf2512f-5a49-4241-a376-b38eeeef042a} TCPHandler: Code: 81. DB::Exception: Database test_h7rxa48p_02911_keeper_map does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a6bd 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x00000000308a1073 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089c809 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6962: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086fd78 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:38.560463 [ 1545 ] {65c41175-4367-4774-9549-0264f1591bc6} RestorerFromBackup: Tables test_xx2kohi6.mv in backup depend on test_xx2kohi6.src, but seems like test_xx2kohi6.src is not in the backup and does not exist. Will try to ignore that and restore tables 2025.03.05 21:08:38.596181 [ 5338 ] {dffe0a4d-5bb9-45fb-b3b0-7a5e25f1c548} executeQuery: Code: 81. DB::Exception: Database test_h7rxa48p_02911_keeper_map does not exist. (UNKNOWN_DATABASE) (version 24.3.12.76.altinitystable) (from [::1]:46274) (comment: 02911_backup_restore_keeper_map.sh) (in query: SELECT count() FROM test_h7rxa48p_02911_keeper_map.02911_backup_restore_keeper_map2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a6bd 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x00000000308a1073 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089c809 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6962: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086fd78 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:38.596462 [ 5338 ] {dffe0a4d-5bb9-45fb-b3b0-7a5e25f1c548} TCPHandler: Code: 81. DB::Exception: Database test_h7rxa48p_02911_keeper_map does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a6bd 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x00000000308a1073 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089c809 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6962: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086fd78 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:38.802791 [ 1579 ] {55e2d78d-f132-49c2-943e-e983d804f6de} executeQuery: Code: 81. DB::Exception: Database test_h7rxa48p_02911_keeper_map does not exist. (UNKNOWN_DATABASE) (version 24.3.12.76.altinitystable) (from [::1]:46292) (comment: 02911_backup_restore_keeper_map.sh) (in query: SELECT count() FROM test_h7rxa48p_02911_keeper_map.02911_backup_restore_keeper_map3;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a6bd 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x00000000308a1073 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089c809 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6962: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086fd78 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:38.803083 [ 1579 ] {55e2d78d-f132-49c2-943e-e983d804f6de} TCPHandler: Code: 81. DB::Exception: Database test_h7rxa48p_02911_keeper_map does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a6bd 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x00000000308a1073 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089c809 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6962: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086fd78 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:39.572143 [ 6357 ] {69878663-d9a9-4f6a-a04b-af00d8c611ed} RestorerFromBackup: Tables test_xx2kohi6.mv in backup depend on test_xx2kohi6.dst, but seems like test_xx2kohi6.dst is not in the backup and does not exist. Will try to ignore that and restore tables 2025.03.05 21:08:39.572179 [ 6357 ] {69878663-d9a9-4f6a-a04b-af00d8c611ed} RestorerFromBackup: Tables test_xx2kohi6.mv in backup depend on test_xx2kohi6.src, but seems like test_xx2kohi6.src is not in the backup and does not exist. Will try to ignore that and restore tables 2025.03.05 21:08:40.321150 [ 1579 ] {5818dbea-dd1e-4762-8528-1b6587badedb} executeQuery: Code: 36. DB::Exception: You must provide an ORDER BY or PRIMARY KEY expression in the table definition. If you don't want this table to be sorted, use ORDER BY/PRIMARY KEY (). Otherwise, you can use the setting 'create_table_empty_primary_key_by_default' to automatically add an empty primary key to the table definition. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:43174) (comment: 02903_empty_order_by_throws_error.sh) (in query: CREATE TABLE test_empty_order_by(a UInt8) ENGINE = MergeTree() SETTINGS index_granularity = 8192;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:542: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306fba3 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:40.321456 [ 1579 ] {5818dbea-dd1e-4762-8528-1b6587badedb} TCPHandler: Code: 36. DB::Exception: You must provide an ORDER BY or PRIMARY KEY expression in the table definition. If you don't want this table to be sorted, use ORDER BY/PRIMARY KEY (). Otherwise, you can use the setting 'create_table_empty_primary_key_by_default' to automatically add an empty primary key to the table definition. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:542: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306fba3 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:40.676762 [ 1008 ] {} test_0bak548e.rmt2 (11987152-65c0-45e2-a583-ab5bef5fadb2): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:619: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000032fa4351 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000324596b3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f0fe371 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002f103012 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002f103e52 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:41.033869 [ 5338 ] {88b40633-55e7-4c36-ac3b-bb1c9c18fd2a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_h7rxa48p_02911_keeper_map.02911_backup_restore_keeper_map3' in scope SELECT count() FROM test_h7rxa48p_02911_keeper_map.`02911_backup_restore_keeper_map3`. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:43298) (comment: 02911_backup_restore_keeper_map.sh) (in query: SELECT count() FROM test_h7rxa48p_02911_keeper_map.02911_backup_restore_keeper_map3;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:41.034178 [ 5338 ] {88b40633-55e7-4c36-ac3b-bb1c9c18fd2a} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_h7rxa48p_02911_keeper_map.02911_backup_restore_keeper_map3' in scope SELECT count() FROM test_h7rxa48p_02911_keeper_map.`02911_backup_restore_keeper_map3`. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:41.142450 [ 5753 ] {56871a91-6c72-4b78-a6a3-ba471a35f36b} executeQuery: Code: 321. DB::Exception: Value -2208988800 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:43310) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDateTime(toDateTime64('1900-01-01 00:00:00.123', 3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x00000000187c209b 4. void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000184cffda 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x00000000184cf7b1 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000184b479d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018496743 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:08:41.142841 [ 5753 ] {56871a91-6c72-4b78-a6a3-ba471a35f36b} TCPHandler: Code: 321. DB::Exception: Value -2208988800 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x00000000187c209b 4. void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000184cffda 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x00000000184cf7b1 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000184b479d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018496743 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:08:41.146042 [ 5753 ] {b8944770-fb4b-4487-b7fa-ffe420ded7b8} executeQuery: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:43310) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDateTime(toDateTime64('2299-12-31 23:59:59.999', 3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x00000000187c209b 4. void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000184cffda 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x00000000184cf7b1 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000184b479d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018496743 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:08:41.146244 [ 5753 ] {b8944770-fb4b-4487-b7fa-ffe420ded7b8} TCPHandler: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x00000000187c209b 4. void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000184cffda 5. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x00000000184cf7b1 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000184b479d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018496743 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:08:41.191753 [ 5753 ] {7c37d70a-d1a6-4c62-a2c8-a8675f0a5d51} executeQuery: Code: 321. DB::Exception: Value -25567 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:43310) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDateTime(toDate32('1900-01-01'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000184cda92 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x00000000184cd22a 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000184add99 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018496743 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:08:41.192011 [ 5753 ] {7c37d70a-d1a6-4c62-a2c8-a8675f0a5d51} TCPHandler: Code: 321. DB::Exception: Value -25567 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000184cda92 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x00000000184cd22a 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000184add99 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018496743 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:08:41.194666 [ 5753 ] {fb3b2cde-9fad-48d7-b432-628193a11efd} executeQuery: Code: 321. DB::Exception: Value 120529 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:43310) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDateTime(toDate32('2299-12-31'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000184cda92 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x00000000184cd22a 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000184add99 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018496743 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:08:41.194879 [ 5753 ] {fb3b2cde-9fad-48d7-b432-628193a11efd} TCPHandler: Code: 321. DB::Exception: Value 120529 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000184cda92 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x00000000184cd22a 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000184add99 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018496743 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:08:41.225870 [ 5753 ] {6c5d3ade-bbc2-49c2-9a2c-233692a6b81a} executeQuery: Code: 321. DB::Exception: Day number 65535 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate('2149-06-06')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:43310) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDateTime(toDate('2149-06-06'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned short&) @ 0x00000000187c1b9b 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000184cb5ac 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x00000000184cad6a 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000184adcd9 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018496743 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:08:41.226184 [ 5753 ] {6c5d3ade-bbc2-49c2-9a2c-233692a6b81a} TCPHandler: Code: 321. DB::Exception: Day number 65535 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate('2149-06-06')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned short&) @ 0x00000000187c1b9b 4. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000184cb5ac 5. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x00000000184cad6a 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000184adcd9 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018496743 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:08:41.260528 [ 5753 ] {f803ede7-b8d8-4c4a-b955-d0d50dcc1476} executeQuery: Code: 321. DB::Exception: Value -2208988799 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:43310) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDate(toDateTime64('1900-01-01 00:00:00.123', 3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x00000000187c209b 4. DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x00000000187e84b2 5. void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000187e832f 6. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x00000000187e7d57 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018648d26 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:08:41.260915 [ 5753 ] {f803ede7-b8d8-4c4a-b955-d0d50dcc1476} TCPHandler: Code: 321. DB::Exception: Value -2208988799 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x00000000187c209b 4. DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x00000000187e84b2 5. void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000187e832f 6. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x00000000187e7d57 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018648d26 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:08:41.263709 [ 5753 ] {f91fbf89-0802-4256-9424-935b69c7cd91} executeQuery: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:43310) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDate(toDateTime64('2299-12-31 23:59:59.999', 3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x00000000187c209b 4. DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x00000000187e84b2 5. void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000187e832f 6. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x00000000187e7d57 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018648d26 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:08:41.263880 [ 5753 ] {f91fbf89-0802-4256-9424-935b69c7cd91} TCPHandler: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x00000000187c209b 4. DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x00000000187e84b2 5. void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000187e832f 6. COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x00000000187e7d57 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018648d26 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:08:41.297110 [ 5753 ] {f266e811-7328-49bb-852d-4b92182652e5} executeQuery: Code: 321. DB::Exception: Value -25567 is out of bounds of type Date: In scope SELECT toDate(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:43310) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDate(toDate32('1900-01-01'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(int, DateLUTImpl const&) @ 0x00000000187e3b6b 5. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000187e3a5c 6. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x00000000187e34f7 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000186454c0 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:08:41.297398 [ 5753 ] {f266e811-7328-49bb-852d-4b92182652e5} TCPHandler: Code: 321. DB::Exception: Value -25567 is out of bounds of type Date: In scope SELECT toDate(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(int, DateLUTImpl const&) @ 0x00000000187e3b6b 5. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000187e3a5c 6. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x00000000187e34f7 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000186454c0 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:08:41.299819 [ 5753 ] {12bdbfcc-cabe-44e1-b57b-52002389eea3} executeQuery: Code: 321. DB::Exception: Value 120529 is out of bounds of type Date: In scope SELECT toDate(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:43310) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDate(toDate32('2299-12-31'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(int, DateLUTImpl const&) @ 0x00000000187e3b6b 5. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000187e3a5c 6. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x00000000187e34f7 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000186454c0 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:08:41.299980 [ 5753 ] {12bdbfcc-cabe-44e1-b57b-52002389eea3} TCPHandler: Code: 321. DB::Exception: Value 120529 is out of bounds of type Date: In scope SELECT toDate(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(int, DateLUTImpl const&) @ 0x00000000187e3b6b 5. void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000187e3a5c 6. COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x00000000187e34f7 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000186454c0 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:08:41.677149 [ 1242 ] {} test_0bak548e.rmt2 (11987152-65c0-45e2-a583-ab5bef5fadb2): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:619: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000032fa4351 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000324596b3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f0fe371 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002f103012 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002f103e52 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:42.504909 [ 1658 ] {e9ba099a-adc3-4572-9ac4-31a3f7862ad4} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:43566) (comment: 02896_illegal_sampling.sql) (in query: SELECT * FROM (SELECT 1) SAMPLE 1 / 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030824df6 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:42.505143 [ 1658 ] {e9ba099a-adc3-4572-9ac4-31a3f7862ad4} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030824df6 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:42.962565 [ 3510 ] {22d00052-3476-4c31-9352-2c2b7fb5411b} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:42336) (comment: 02899_use_default_format_on_http_exception.sh) (in query: SELECT x FROM system.numbers LIMIT 1; ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 7. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 18. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:42.963099 [ 3510 ] {22d00052-3476-4c31-9352-2c2b7fb5411b} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 7. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 18. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:42.986860 [ 3510 ] {9f46284f-6ead-4968-a3b7-246b26637db9} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:42350) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./src/Storages/IStorage.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002e517516 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:42.987294 [ 3510 ] {9f46284f-6ead-4968-a3b7-246b26637db9} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./src/Storages/IStorage.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002e517516 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:42.997327 [ 3510 ] {b2536628-2ec0-40c8-a29a-417270c7b7da} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:42362) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./src/Storages/IStorage.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002e517516 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:42.997749 [ 3510 ] {b2536628-2ec0-40c8-a29a-417270c7b7da} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./src/Storages/IStorage.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002e517516 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:43.006124 [ 3510 ] {751016d3-e5bf-4dfe-860e-0598ac5190bd} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:42368) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./src/Storages/IStorage.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002e517516 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:43.023052 [ 3510 ] {751016d3-e5bf-4dfe-860e-0598ac5190bd} executeQuery: Code: 73. DB::Exception: Unknown format BADFORMAT. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Formats/FormatFactory.cpp:44: DB::FormatFactory::getCreators(String const&) const @ 0x00000000334e8523 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x00000000334ec829 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function)::$_1::operator()() const @ 0x0000000031705863 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031705050 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:43.023259 [ 3510 ] {751016d3-e5bf-4dfe-860e-0598ac5190bd} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./src/Storages/IStorage.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002e517516 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:43.032286 [ 3510 ] {fe7ac6f4-b3d6-47d7-b54f-916ca98c60f2} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:42378) (comment: 02899_use_default_format_on_http_exception.sh) (in query: SELECT x FROM system.numbers LIMIT 1; ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 7. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 18. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:43.032605 [ 3510 ] {fe7ac6f4-b3d6-47d7-b54f-916ca98c60f2} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 7. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 18. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:43.042573 [ 3510 ] {977ed44e-0e7f-48f3-af84-1cafbfae559f} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:42390) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./src/Storages/IStorage.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002e517516 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:43.042953 [ 3510 ] {977ed44e-0e7f-48f3-af84-1cafbfae559f} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./src/Storages/IStorage.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002e517516 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:43.051852 [ 3510 ] {808c43c1-6fa3-40f6-9a27-f05e1170e78d} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:42402) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./src/Storages/IStorage.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002e517516 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:43.052213 [ 3510 ] {808c43c1-6fa3-40f6-9a27-f05e1170e78d} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./src/Storages/IStorage.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002e517516 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:43.060441 [ 3510 ] {043249af-f8f3-48b5-972f-2d6aab4d2dc6} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:42418) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./src/Storages/IStorage.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002e517516 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:43.060725 [ 3510 ] {043249af-f8f3-48b5-972f-2d6aab4d2dc6} executeQuery: Code: 73. DB::Exception: Unknown format BADFORMAT. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Formats/FormatFactory.cpp:44: DB::FormatFactory::getCreators(String const&) const @ 0x00000000334e8523 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x00000000334ec829 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function)::$_1::operator()() const @ 0x0000000031705863 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031705050 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:43.060893 [ 3510 ] {043249af-f8f3-48b5-972f-2d6aab4d2dc6} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./src/Storages/IStorage.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002e517516 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:44.501507 [ 3510 ] {bd9e0cc9-1bcc-4d12-9ddc-140c97b9bb57} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 1.00, current rows: 121.00: While executing EmbeddedRocksDB. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:43772) (comment: 02892_rocksdb_trivial_count.sql) (in query: -- { echoOn } SELECT count() FROM dict SETTINGS optimize_trivial_approximate_count_query = 0, max_rows_to_read = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f3d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 9. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 10. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:44.501862 [ 3510 ] {bd9e0cc9-1bcc-4d12-9ddc-140c97b9bb57} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 1.00, current rows: 121.00: While executing EmbeddedRocksDB. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f3d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 9. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 10. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:44.731991 [ 3510 ] {9c8d05d9-a4e6-42af-b39d-b1745f21f662} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 0, should be 2: In scope SELECT arrayShingles(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:43808) (comment: 02891_array_shingles.sql) (in query: SELECT arrayShingles();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:44.732192 [ 3510 ] {9c8d05d9-a4e6-42af-b39d-b1745f21f662} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 0, should be 2: In scope SELECT arrayShingles(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:44.734367 [ 3510 ] {987882d8-b03e-49da-8527-087086fd04db} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 1, should be 2: In scope SELECT arrayShingles([1, 2, 3, 4, 5]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:43808) (comment: 02891_array_shingles.sql) (in query: SELECT arrayShingles([1, 2, 3, 4, 5]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:44.734548 [ 3510 ] {987882d8-b03e-49da-8527-087086fd04db} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 1, should be 2: In scope SELECT arrayShingles([1, 2, 3, 4, 5]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:44.736710 [ 3510 ] {d577ed83-6cd6-4000-80bc-e0a2e715c0d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles([1, 2, 3, 4, 5], 2, 3). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:43808) (comment: 02891_array_shingles.sql) (in query: SELECT arrayShingles([1, 2, 3, 4, 5], 2, 3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:44.736895 [ 3510 ] {d577ed83-6cd6-4000-80bc-e0a2e715c0d4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles([1, 2, 3, 4, 5], 2, 3). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:44.765809 [ 3510 ] {b06b535b-6684-41bb-ab0d-9be275da887e} executeQuery: Code: 43. DB::Exception: Illegal type of argument #2 'length' of function arrayShingles, expected Integer, got String: In scope SELECT arrayShingles([1, 2, 3, 4, 5], 'str'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:43808) (comment: 02891_array_shingles.sql) (in query: SELECT arrayShingles([1, 2, 3, 4, 5], 'str');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionArrayShingles::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023dbd7b9 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:44.766012 [ 3510 ] {b06b535b-6684-41bb-ab0d-9be275da887e} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #2 'length' of function arrayShingles, expected Integer, got String: In scope SELECT arrayShingles([1, 2, 3, 4, 5], 'str'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionArrayShingles::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023dbd7b9 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:44.768059 [ 3510 ] {b0e4d81b-a5db-4f02-99b0-16bff0c4286f} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'array' of function arrayShingles, expected Array, got Tuple(UInt8, UInt8, UInt8, UInt8, UInt8): In scope SELECT arrayShingles((1, 2, 3, 4, 5), 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:43808) (comment: 02891_array_shingles.sql) (in query: SELECT arrayShingles((1, 2, 3, 4, 5), 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionArrayShingles::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023dbd7b9 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:44.768173 [ 3510 ] {b0e4d81b-a5db-4f02-99b0-16bff0c4286f} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'array' of function arrayShingles, expected Array, got Tuple(UInt8, UInt8, UInt8, UInt8, UInt8): In scope SELECT arrayShingles((1, 2, 3, 4, 5), 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionArrayShingles::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023dbd7b9 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:44.797176 [ 3510 ] {a0f3cbc4-81ae-4e6e-bacd-c7c11a734e44} executeQuery: Code: 36. DB::Exception: Shingle argument of function arrayShingles must be a positive integer.: In scope SELECT arrayShingles([1, 2, 3, 4, 5], 0). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:43808) (comment: 02891_array_shingles.sql) (in query: SELECT arrayShingles([1, 2, 3, 4, 5], 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayShingles::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023dbd124 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:44.797397 [ 3510 ] {a0f3cbc4-81ae-4e6e-bacd-c7c11a734e44} TCPHandler: Code: 36. DB::Exception: Shingle argument of function arrayShingles must be a positive integer.: In scope SELECT arrayShingles([1, 2, 3, 4, 5], 0). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayShingles::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023dbd124 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:44.799427 [ 3510 ] {c1a85e01-03d8-4325-bfd2-24ff54f813b3} executeQuery: Code: 36. DB::Exception: Shingle argument of function arrayShingles must be a positive integer.: In scope SELECT arrayShingles([1, 2, 3, 4, 5], -2). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:43808) (comment: 02891_array_shingles.sql) (in query: SELECT arrayShingles([1, 2, 3, 4, 5], -2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayShingles::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023dbd124 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:44.799552 [ 3510 ] {c1a85e01-03d8-4325-bfd2-24ff54f813b3} TCPHandler: Code: 36. DB::Exception: Shingle argument of function arrayShingles must be a positive integer.: In scope SELECT arrayShingles([1, 2, 3, 4, 5], -2). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayShingles::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023dbd124 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:44.829819 [ 3510 ] {81499a33-4aa6-47bf-bd32-e8f33c09433e} executeQuery: Code: 36. DB::Exception: Shingle argument of function arrayShingles must less or equal than the array length.: In scope SELECT arrayShingles([1, 2, 3, 4, 5], 6). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:43808) (comment: 02891_array_shingles.sql) (in query: SELECT arrayShingles([1, 2, 3, 4, 5], 6);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayShingles::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023dbd024 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:44.860132 [ 5753 ] {32d7fb15-cff9-4326-8995-cabd2dd18bc7} executeQuery: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime64(3, 'UTC') from String: In scope SELECT toDateTime64('1234', 3, 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:43828) (comment: 02889_datetime64_from_string.sql) (in query: SELECT toDateTime64('1234', 3, 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/ReadHelpers.cpp:0: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000247218a4 5. void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000187bf3d4 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867f8ee 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:08:44.860148 [ 3510 ] {81499a33-4aa6-47bf-bd32-e8f33c09433e} TCPHandler: Code: 36. DB::Exception: Shingle argument of function arrayShingles must less or equal than the array length.: In scope SELECT arrayShingles([1, 2, 3, 4, 5], 6). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayShingles::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023dbd024 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:44.860475 [ 5753 ] {32d7fb15-cff9-4326-8995-cabd2dd18bc7} TCPHandler: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime64(3, 'UTC') from String: In scope SELECT toDateTime64('1234', 3, 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/ReadHelpers.cpp:0: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000247218a4 5. void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000187bf3d4 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867f8ee 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:08:44.862561 [ 3510 ] {07bef258-463d-41e6-ae24-eb4398f7188e} executeQuery: Code: 36. DB::Exception: Shingle argument of function arrayShingles must less or equal than the array length.: In scope SELECT arrayShingles([], 1). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:43808) (comment: 02891_array_shingles.sql) (in query: SELECT arrayShingles([], 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayShingles::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023dbd024 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:44.862571 [ 5753 ] {f514b28b-f149-4d9a-8892-891ccfbcdc7d} executeQuery: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime64(3, 'UTC') from String: In scope SELECT toDateTime64('0', 3, 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:43828) (comment: 02889_datetime64_from_string.sql) (in query: SELECT toDateTime64('0', 3, 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/ReadHelpers.cpp:0: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000247218a4 5. void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000187bf3d4 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867f8ee 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:08:44.862720 [ 5753 ] {f514b28b-f149-4d9a-8892-891ccfbcdc7d} TCPHandler: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime64(3, 'UTC') from String: In scope SELECT toDateTime64('0', 3, 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/ReadHelpers.cpp:0: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000247218a4 5. void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000187bf3d4 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867f8ee 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:08:44.862733 [ 3510 ] {07bef258-463d-41e6-ae24-eb4398f7188e} TCPHandler: Code: 36. DB::Exception: Shingle argument of function arrayShingles must less or equal than the array length.: In scope SELECT arrayShingles([], 1). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayShingles::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023dbd024 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:44.891630 [ 5753 ] {c06c3f6e-ce9b-42f7-b032-1af0528b6055} executeQuery: Code: 41. DB::Exception: Cannot parse DateTime: In scope SELECT CAST('0', 'DateTime64(3, \'UTC\')'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:43828) (comment: 02889_datetime64_from_string.sql) (in query: SELECT cast('0' as DateTime64(3, 'UTC'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/ReadHelpers.cpp:0: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000247218a4 5. void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000187bf3d4 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, unsigned int) @ 0x00000000184f0b96 7. bool DB::callOnIndexAndDataType::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper(std::shared_ptr const&, DB::DataTypeDateTime64 const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDateTime64 const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper(std::shared_ptr const&, DB::DataTypeDateTime64 const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDateTime64 const&)&&) @ 0x00000000184eceb2 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper(std::shared_ptr const&, DB::DataTypeDateTime64 const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000184e9063 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:08:44.891801 [ 5753 ] {c06c3f6e-ce9b-42f7-b032-1af0528b6055} TCPHandler: Code: 41. DB::Exception: Cannot parse DateTime: In scope SELECT CAST('0', 'DateTime64(3, \'UTC\')'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/ReadHelpers.cpp:0: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000247218a4 5. void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000187bf3d4 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, unsigned int) @ 0x00000000184f0b96 7. bool DB::callOnIndexAndDataType::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper(std::shared_ptr const&, DB::DataTypeDateTime64 const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDateTime64 const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper(std::shared_ptr const&, DB::DataTypeDateTime64 const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDateTime64 const&)&&) @ 0x00000000184eceb2 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper(std::shared_ptr const&, DB::DataTypeDateTime64 const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000184e9063 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:08:45.340101 [ 5338 ] {92590a19-ca8f-449b-8645-887224e2cb60} PostgreSQLConnectionPool: Connection error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? 2025.03.05 21:08:45.340268 [ 5338 ] {92590a19-ca8f-449b-8645-887224e2cb60} PostgreSQLConnectionPool: Connection error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? 2025.03.05 21:08:45.359241 [ 5338 ] {92590a19-ca8f-449b-8645-887224e2cb60} executeQuery: Code: 614. DB::Exception: Try 2. Connection to `127.121.0.1:5432` failed with error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? . (POSTGRESQL_CONNECTION_FAILURE) (version 24.3.12.76.altinitystable) (from [::1]:43942) (comment: 02888_system_tables_with_inaccessible_table_function.sql) (in query: CREATE TABLE test_zlmfp7p4.tablefunc01_without_schema AS postgresql('127.121.0.1:5432', 'postgres_db', 'postgres_table', 'postgres_user', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002e437716 4. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:135: postgres::PoolWithFailover::get() @ 0x000000002eb00a34 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:99: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000003236e6b7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::TableFunctionPostgreSQL::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4e55df 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:824: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b7605 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:45.359502 [ 5338 ] {92590a19-ca8f-449b-8645-887224e2cb60} TCPHandler: Code: 614. DB::Exception: Try 2. Connection to `127.121.0.1:5432` failed with error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? . (POSTGRESQL_CONNECTION_FAILURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002e437716 4. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:135: postgres::PoolWithFailover::get() @ 0x000000002eb00a34 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:99: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000003236e6b7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::TableFunctionPostgreSQL::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4e55df 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:824: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b7605 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:45.362112 [ 5338 ] {f98a9ace-1dc6-43b2-88cc-c5034d2f4791} mysqlxx::Pool: Failed to connect to MySQL (mysql_db@127.123.0.1:3306 as user mysql_user): mysqlxx::ConnectionFailed 2025.03.05 21:08:45.362162 [ 5338 ] {f98a9ace-1dc6-43b2-88cc-c5034d2f4791} Application: Connection to mysql_db@127.123.0.1:3306 as user mysql_user failed: mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.123.0.1' (115) ((nullptr):0) 2025.03.05 21:08:45.362172 [ 5338 ] {f98a9ace-1dc6-43b2-88cc-c5034d2f4791} Application: Connection to mysql failed 1 times 2025.03.05 21:08:45.362274 [ 5338 ] {f98a9ace-1dc6-43b2-88cc-c5034d2f4791} mysqlxx::Pool: Failed to connect to MySQL (mysql_db@127.123.0.1:3306 as user mysql_user): mysqlxx::ConnectionFailed 2025.03.05 21:08:45.362313 [ 5338 ] {f98a9ace-1dc6-43b2-88cc-c5034d2f4791} Application: Connection to mysql_db@127.123.0.1:3306 as user mysql_user failed: mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.123.0.1' (115) ((nullptr):0) 2025.03.05 21:08:45.362321 [ 5338 ] {f98a9ace-1dc6-43b2-88cc-c5034d2f4791} Application: Connection to mysql failed 2 times 2025.03.05 21:08:45.362411 [ 5338 ] {f98a9ace-1dc6-43b2-88cc-c5034d2f4791} mysqlxx::Pool: Failed to connect to MySQL (mysql_db@127.123.0.1:3306 as user mysql_user): mysqlxx::ConnectionFailed 2025.03.05 21:08:45.362457 [ 5338 ] {f98a9ace-1dc6-43b2-88cc-c5034d2f4791} Application: Connection to mysql_db@127.123.0.1:3306 as user mysql_user failed: mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.123.0.1' (115) ((nullptr):0) 2025.03.05 21:08:45.362465 [ 5338 ] {f98a9ace-1dc6-43b2-88cc-c5034d2f4791} Application: Connection to mysql failed 3 times 2025.03.05 21:08:45.385269 [ 5338 ] {f98a9ace-1dc6-43b2-88cc-c5034d2f4791} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: mysql_db@127.123.0.1:3306 as user mysql_user, ERROR 2002 : mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.123.0.1' (115) ((nullptr):0). (ALL_CONNECTION_TRIES_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:43942) (comment: 02888_system_tables_with_inaccessible_table_function.sql) (in query: CREATE TABLE test_zlmfp7p4.tablefunc02_without_schema AS mysql('127.123.0.1:3306', 'mysql_db', 'mysql_table', 'mysql_user', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::TableFunctionMySQL::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4e18ff 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:824: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b7605 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:45.385472 [ 5338 ] {f98a9ace-1dc6-43b2-88cc-c5034d2f4791} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: mysql_db@127.123.0.1:3306 as user mysql_user, ERROR 2002 : mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.123.0.1' (115) ((nullptr):0). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::TableFunctionMySQL::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4e18ff 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:824: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b7605 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:45.713935 [ 5338 ] {aabd691c-edc1-4f20-a197-d19ea120cf9d} executeQuery: Code: 36. DB::Exception: Tables have different secondary indices. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:43974) (comment: 02888_attach_partition_from_different_tables.sql) (in query: ALTER TABLE attach_partition_t2 ATTACH PARTITION tuple() FROM attach_partition_t1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000032bb3f21 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x00000000330ba768 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032b81d41 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307959bb 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:45.714168 [ 5338 ] {aabd691c-edc1-4f20-a197-d19ea120cf9d} TCPHandler: Code: 36. DB::Exception: Tables have different secondary indices. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000032bb3f21 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x00000000330ba768 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032b81d41 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307959bb 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:45.762774 [ 5338 ] {11e96c24-fb04-4361-8838-9aa4b3c992df} executeQuery: Code: 36. DB::Exception: Tables have different projections. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:43974) (comment: 02888_attach_partition_from_different_tables.sql) (in query: ALTER TABLE attach_partition_t4 ATTACH PARTITION tuple() FROM attach_partition_t3;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000032bb3fbd 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x00000000330ba768 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032b81d41 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307959bb 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:45.762985 [ 5338 ] {11e96c24-fb04-4361-8838-9aa4b3c992df} TCPHandler: Code: 36. DB::Exception: Tables have different projections. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000032bb3fbd 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x00000000330ba768 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032b81d41 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307959bb 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:45.898507 [ 5753 ] {8cf622ed-7b8e-4b09-b583-0706ce8594a2} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.3.12.76.altinitystable) (from [::1]:44028) (comment: 02892_input_csv_cr_end_count_many_rows.sh) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:45.898852 [ 5753 ] {8cf622ed-7b8e-4b09-b583-0706ce8594a2} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.175910 [ 1658 ] {473518a2-bb14-407e-845a-409eb862f14d} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 0, should be 1: In scope SELECT byteSwap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:44058) (comment: 02887_byteswap.sql) (in query: -- Number of arguments should equal 1 SELECT byteSwap();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.176035 [ 1658 ] {473518a2-bb14-407e-845a-409eb862f14d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 0, should be 1: In scope SELECT byteSwap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.177541 [ 1658 ] {85c82a18-484c-406b-a641-6c54527c2576} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap(128, 129). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:44058) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(128, 129);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.177668 [ 1658 ] {85c82a18-484c-406b-a641-6c54527c2576} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap(128, 129). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.203879 [ 1658 ] {52582933-1088-40aa-a6b7-b47a88d24d14} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function byteSwap: In scope SELECT byteSwap('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:44058) (comment: 02887_byteswap.sql) (in query: -- Input should be integral SELECT byteSwap('abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a8af059 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.204055 [ 1658 ] {52582933-1088-40aa-a6b7-b47a88d24d14} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function byteSwap: In scope SELECT byteSwap('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a8af059 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.206061 [ 1658 ] {768a6b8a-ec76-4da7-b0c0-ed80437424c6} executeQuery: Code: 43. DB::Exception: Illegal type FixedString(3) of argument of function byteSwap: In scope SELECT byteSwap(toFixedString('abc', 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:44058) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(toFixedString('abc', 3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a8af059 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.206168 [ 1658 ] {768a6b8a-ec76-4da7-b0c0-ed80437424c6} TCPHandler: Code: 43. DB::Exception: Illegal type FixedString(3) of argument of function byteSwap: In scope SELECT byteSwap(toFixedString('abc', 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a8af059 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.207542 [ 1658 ] {8d9083f0-18dd-4ba7-ad6c-aef64672035c} executeQuery: Code: 43. DB::Exception: Illegal type Date of argument of function byteSwap: In scope SELECT byteSwap(toDate('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:44058) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(toDate('2019-01-01'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a8af059 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.207656 [ 1658 ] {8d9083f0-18dd-4ba7-ad6c-aef64672035c} TCPHandler: Code: 43. DB::Exception: Illegal type Date of argument of function byteSwap: In scope SELECT byteSwap(toDate('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a8af059 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.209012 [ 1658 ] {8a38f54f-39d8-4da1-a9bf-f9fe1f0c62d4} executeQuery: Code: 43. DB::Exception: Illegal type Date32 of argument of function byteSwap: In scope SELECT byteSwap(toDate32('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:44058) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(toDate32('2019-01-01'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a8af059 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.209116 [ 1658 ] {8a38f54f-39d8-4da1-a9bf-f9fe1f0c62d4} TCPHandler: Code: 43. DB::Exception: Illegal type Date32 of argument of function byteSwap: In scope SELECT byteSwap(toDate32('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a8af059 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.210520 [ 1658 ] {ec979ced-0d49-404f-9b80-819a6461d54c} executeQuery: Code: 43. DB::Exception: Illegal type DateTime of argument of function byteSwap: In scope SELECT byteSwap(toDateTime32(1546300800)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:44058) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(toDateTime32(1546300800));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a8af059 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.210631 [ 1658 ] {ec979ced-0d49-404f-9b80-819a6461d54c} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime of argument of function byteSwap: In scope SELECT byteSwap(toDateTime32(1546300800)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a8af059 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.211970 [ 1658 ] {77594e12-2f92-4adf-95da-994c080ed72b} executeQuery: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument of function byteSwap: In scope SELECT byteSwap(toDateTime64(1546300800, 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:44058) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(toDateTime64(1546300800, 3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a8af059 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.212061 [ 1658 ] {77594e12-2f92-4adf-95da-994c080ed72b} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument of function byteSwap: In scope SELECT byteSwap(toDateTime64(1546300800, 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a8af059 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.213527 [ 1658 ] {71cfcb27-907d-4e28-8a1c-3c85eeab1226} executeQuery: Code: 43. DB::Exception: Illegal type UUID of argument of function byteSwap: In scope SELECT byteSwap(generateUUIDv4()). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:44058) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(generateUUIDv4());), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a8af059 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.213654 [ 1658 ] {71cfcb27-907d-4e28-8a1c-3c85eeab1226} TCPHandler: Code: 43. DB::Exception: Illegal type UUID of argument of function byteSwap: In scope SELECT byteSwap(generateUUIDv4()). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a8af059 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.214931 [ 1658 ] {62b049db-3e96-4645-afdd-5b7d89bb681f} executeQuery: Code: 43. DB::Exception: Illegal type Decimal(9, 4) of argument of function byteSwap: In scope SELECT byteSwap(toDecimal32(2, 4)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:44058) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(toDecimal32(2, 4));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a8af059 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.215030 [ 1658 ] {62b049db-3e96-4645-afdd-5b7d89bb681f} TCPHandler: Code: 43. DB::Exception: Illegal type Decimal(9, 4) of argument of function byteSwap: In scope SELECT byteSwap(toDecimal32(2, 4)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a8af059 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.246989 [ 1658 ] {3d6920f1-306a-45e6-81ad-afe4bd53dc3e} executeQuery: Code: 48. DB::Exception: byteSwap() is not implemented for float datatype: In scope SELECT byteSwap(toFloat32(123.456)). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:44058) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(toFloat32(123.456));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::ByteSwapImpl::apply(float) @ 0x000000001a8b9e92 5. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000001a8b9d11 6. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000001a8b37a0 7. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS1_IfEENS1_IdEENS_15DataTypeDecimalINS_7DecimalIiEEEENSN_INSO_IlEEEENSN_INSO_ISH_EEEENSN_INSO_ISJ_EEEENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZNKS_23FunctionUnaryArithmeticINS_12_GLOBAL__N_112ByteSwapImplENS12_12NameByteSwapELb1EE11executeImplERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS16_9allocatorIS18_EEEERKNS16_10shared_ptrIKS10_EEmEUlRKT_E_EEbPKT0_OT1_ @ 0x000000001a8b17dc 8. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a8adced 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:08:46.247165 [ 1658 ] {3d6920f1-306a-45e6-81ad-afe4bd53dc3e} TCPHandler: Code: 48. DB::Exception: byteSwap() is not implemented for float datatype: In scope SELECT byteSwap(toFloat32(123.456)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::ByteSwapImpl::apply(float) @ 0x000000001a8b9e92 5. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000001a8b9d11 6. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000001a8b37a0 7. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS1_IfEENS1_IdEENS_15DataTypeDecimalINS_7DecimalIiEEEENSN_INSO_IlEEEENSN_INSO_ISH_EEEENSN_INSO_ISJ_EEEENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZNKS_23FunctionUnaryArithmeticINS_12_GLOBAL__N_112ByteSwapImplENS12_12NameByteSwapELb1EE11executeImplERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS16_9allocatorIS18_EEEERKNS16_10shared_ptrIKS10_EEmEUlRKT_E_EEbPKT0_OT1_ @ 0x000000001a8b17dc 8. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a8adced 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:08:46.278370 [ 1658 ] {51857bda-18c4-4caf-a563-c126c6b7c508} executeQuery: Code: 48. DB::Exception: byteSwap() is not implemented for double datatype: In scope SELECT byteSwap(toFloat64(123.456)). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:44058) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(toFloat64(123.456));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::ByteSwapImpl::apply(double) @ 0x000000001a8ba232 5. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000001a8ba0b1 6. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000001a8b3c00 7. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS1_IfEENS1_IdEENS_15DataTypeDecimalINS_7DecimalIiEEEENSN_INSO_IlEEEENSN_INSO_ISH_EEEENSN_INSO_ISJ_EEEENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZNKS_23FunctionUnaryArithmeticINS_12_GLOBAL__N_112ByteSwapImplENS12_12NameByteSwapELb1EE11executeImplERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS16_9allocatorIS18_EEEERKNS16_10shared_ptrIKS10_EEmEUlRKT_E_EEbPKT0_OT1_ @ 0x000000001a8b181c 8. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a8adced 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:08:46.278599 [ 1658 ] {51857bda-18c4-4caf-a563-c126c6b7c508} TCPHandler: Code: 48. DB::Exception: byteSwap() is not implemented for double datatype: In scope SELECT byteSwap(toFloat64(123.456)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::ByteSwapImpl::apply(double) @ 0x000000001a8ba232 5. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000001a8ba0b1 6. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000001a8b3c00 7. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS1_IfEENS1_IdEENS_15DataTypeDecimalINS_7DecimalIiEEEENSN_INSO_IlEEEENSN_INSO_ISH_EEEENSN_INSO_ISJ_EEEENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZNKS_23FunctionUnaryArithmeticINS_12_GLOBAL__N_112ByteSwapImplENS12_12NameByteSwapELb1EE11executeImplERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS16_9allocatorIS18_EEEERKNS16_10shared_ptrIKS10_EEmEUlRKT_E_EEbPKT0_OT1_ @ 0x000000001a8b181c 8. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a8adced 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:08:46.367069 [ 5753 ] {f82a9db8-af7c-48ae-bb8f-aa3cf72ff33b} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.3.12.76.altinitystable) (from [::1]:44142) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.367194 [ 5753 ] {f82a9db8-af7c-48ae-bb8f-aa3cf72ff33b} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.576751 [ 5338 ] {3d527397-550a-4629-9c45-ed270ff537ca} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function with ArgMin suffix. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:44170) (comment: 02885_arg_min_max_combinator.sql) (in query: select sumArgMin() from numbers(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:0: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000028db5445 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7c3d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.576984 [ 5338 ] {3d527397-550a-4629-9c45-ed270ff537ca} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function with ArgMin suffix. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:0: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000028db5445 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7c3d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.600654 [ 5338 ] {3309d2d2-eeb9-4877-81a6-6588e10f1a1b} executeQuery: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:44170) (comment: 02885_arg_min_max_combinator.sql) (in query: select sumArgMin(number) from numbers(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSum.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000273a2c64 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:248: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7d32 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.600919 [ 5338 ] {3309d2d2-eeb9-4877-81a6-6588e10f1a1b} TCPHandler: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSum.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000273a2c64 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:248: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7d32 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.624796 [ 5338 ] {47a4d2f0-d344-443a-96eb-0f73627bcdc1} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(sum, UInt64) for combinator sumArgMin because the values of that data type are not comparable. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:44170) (comment: 02885_arg_min_max_combinator.sql) (in query: -- Try passing a non comparable type, for example an AggregationState select sumArgMin(number, unhex('0000000000000000')::AggregateFunction(sum, UInt64)) from numbers(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:0: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028db6307 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:46.625079 [ 5338 ] {47a4d2f0-d344-443a-96eb-0f73627bcdc1} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(sum, UInt64) for combinator sumArgMin because the values of that data type are not comparable. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:0: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028db6307 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:47.258716 [ 1343 ] {} ad92d1dd-97a8-40ad-87c9-f2ef6a1c4b73::all_0_4_12_5 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003436efff 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:66: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000003436d557 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000323e8fd3 7. ./contrib/llvm-project/libcxx/include/vector:580: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x0000000032a7c5b8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032f3f263 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000032f3c41e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032addf0f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032adec9e 12. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 13. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:47.258865 [ 1343 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad92d1dd-97a8-40ad-87c9-f2ef6a1c4b73::all_0_4_12_5}: Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003436efff 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:66: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000003436d557 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000323e8fd3 7. ./contrib/llvm-project/libcxx/include/vector:580: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x0000000032a7c5b8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032f3f263 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000032f3c41e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032addf0f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032adec9e 12. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 13. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:48.035759 [ 913 ] {} test_wujw9ag5.table_with_unsuccessful_commits (ad92d1dd-97a8-40ad-87c9-f2ef6a1c4b73): The local set of parts of table test_wujw9ag5.table_with_unsuccessful_commits (ad92d1dd-97a8-40ad-87c9-f2ef6a1c4b73) doesn't look like the set of parts in ZooKeeper: 30.00 rows of 350.00 total rows in filesystem are suspicious. There are 1 uncovered unexpected parts with 30 rows (1 of them is not just-written with 30 rows), 0 missing parts (with 0 blocks), 0 covered unexpected parts (with 0 rows). 2025.03.05 21:08:48.047855 [ 1342 ] {} ad92d1dd-97a8-40ad-87c9-f2ef6a1c4b73::all_0_4_12_5 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003436efff 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:66: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000003436d557 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000323e8fd3 7. ./contrib/llvm-project/libcxx/include/vector:580: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x0000000032a7c5b8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032f3f263 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000032f3c41e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032addf0f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032adec9e 12. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 13. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:48.048030 [ 1342 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ad92d1dd-97a8-40ad-87c9-f2ef6a1c4b73::all_0_4_12_5}: Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003436efff 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:66: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000003436d557 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000323e8fd3 7. ./contrib/llvm-project/libcxx/include/vector:580: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x0000000032a7c5b8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032f3f263 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000032f3c41e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032addf0f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032adec9e 12. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 13. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:48.653075 [ 1658 ] {25c2534b-63da-4c0f-a129-f4a36e5b6cbe} executeQuery: Code: 497. DB::Exception: test_cch7dagp_restricted_user_175532762: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_cch7dagp.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_cch7dagp.dict, 'value', key) String : 5'. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:44450) (comment: 02885_async_insert_access_check_for_defaults.sh) (in query: INSERT INTO table_with_default (key) VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed6f18b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002ed6dbe3 6. ./build_docker/./src/Access/ContextAccess.cpp:726: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002ed2b09a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002fc97417 8. ./build_docker/./src/Interpreters/Context.cpp:1403: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002fc4e4a5 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000018813cba 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001880f625 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018848656 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000033b53941 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 24. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:48.653425 [ 1658 ] {25c2534b-63da-4c0f-a129-f4a36e5b6cbe} TCPHandler: Code: 497. DB::Exception: test_cch7dagp_restricted_user_175532762: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_cch7dagp.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_cch7dagp.dict, 'value', key) String : 5'. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed6f18b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002ed6dbe3 6. ./build_docker/./src/Access/ContextAccess.cpp:726: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002ed2b09a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002fc97417 8. ./build_docker/./src/Interpreters/Context.cpp:1403: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002fc4e4a5 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000018813cba 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001880f625 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018848656 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000033b53941 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 24. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:48.943215 [ 1888 ] {607972d3-e6b1-4613-9c59-bbee932b2eee} executeQuery: Code: 497. DB::Exception: test_cch7dagp_restricted_user_175532762: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_cch7dagp.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_cch7dagp.dict, 'value', key) String : 5'. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 02885_async_insert_access_check_for_defaults.sh) (in query: INSERT INTO test_cch7dagp.table_with_default (key) FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed6f18b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002ed6dbe3 6. ./build_docker/./src/Access/ContextAccess.cpp:726: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002ed2b09a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002fc97417 8. ./build_docker/./src/Interpreters/Context.cpp:1403: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002fc4e4a5 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000018813cba 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001880f625 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018848656 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000033b53941 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 26. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002fc02b29 28. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002fc06b2b 29. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 30. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 31. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 2025.03.05 21:08:48.943511 [ 1888 ] {} AsynchronousInsertQueue: Failed insertion for query 'INSERT INTO test_cch7dagp.table_with_default (key) FORMAT Values': Code: 497. DB::Exception: test_cch7dagp_restricted_user_175532762: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_cch7dagp.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_cch7dagp.dict, 'value', key) String : 5'. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed6f18b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002ed6dbe3 6. ./build_docker/./src/Access/ContextAccess.cpp:726: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002ed2b09a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002fc97417 8. ./build_docker/./src/Interpreters/Context.cpp:1403: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002fc4e4a5 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000018813cba 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001880f625 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018848656 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000033b53941 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 26. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002fc02b29 28. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002fc06b2b 29. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 30. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 31. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:48.944186 [ 3522 ] {a4ac6368-07d8-48ce-8547-3aed124be4a7} executeQuery: Code: 497. DB::Exception: test_cch7dagp_restricted_user_175532762: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_cch7dagp.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_cch7dagp.dict, 'value', key) String : 5': While executing WaitForAsyncInsert. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:44512) (comment: 02885_async_insert_access_check_for_defaults.sh) (in query: INSERT INTO table_with_default (key) VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed6f18b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002ed6dbe3 6. ./build_docker/./src/Access/ContextAccess.cpp:726: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002ed2b09a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002fc97417 8. ./build_docker/./src/Interpreters/Context.cpp:1403: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002fc4e4a5 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000018813cba 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001880f625 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018848656 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000033b53941 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 26. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002fc02b29 28. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002fc06b2b 29. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 30. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 31. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 2025.03.05 21:08:48.944499 [ 3522 ] {a4ac6368-07d8-48ce-8547-3aed124be4a7} TCPHandler: Code: 497. DB::Exception: test_cch7dagp_restricted_user_175532762: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_cch7dagp.dict: while executing 'FUNCTION dictGetString(__dictGetString :: 1, 'value' :: 2, key :: 0) -> dictGetString(test_cch7dagp.dict, 'value', key) String : 5': While executing WaitForAsyncInsert. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed6f18b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002ed6dbe3 6. ./build_docker/./src/Access/ContextAccess.cpp:726: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002ed2b09a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002fc97417 8. ./build_docker/./src/Interpreters/Context.cpp:1403: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002fc4e4a5 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000018813cba 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001880f625 11. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018848656 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000033b53941 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 26. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002fc02b29 28. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002fc06b2b 29. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 30. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 31. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 2025.03.05 21:08:50.326993 [ 5753 ] {80434883-691b-4955-bb4b-ae55bc72d5d9} executeQuery: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35602) (comment: 02883_named_collections_override.sh) (in query: SELECT * FROM url(02883_named_collections_override_test_jfm58sdn_collection1, url='http://127.0.0.1:8123?query=select+2');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000321186e4 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.327190 [ 5753 ] {80434883-691b-4955-bb4b-ae55bc72d5d9} TCPHandler: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000321186e4 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.447172 [ 5753 ] {5490334a-2153-4f4f-818c-427085ff1ed3} executeQuery: Code: 36. DB::Exception: Override not allowed because setting allow_override_by_default is disabled. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35602) (comment: 02883_named_collections_override.sh) (in query: SELECT * FROM url(02883_named_collections_override_test_jfm58sdn_collection1, headers('Accept'='text/csv; charset=utf-8'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x000000003211877d 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.447423 [ 5753 ] {5490334a-2153-4f4f-818c-427085ff1ed3} TCPHandler: Code: 36. DB::Exception: Override not allowed because setting allow_override_by_default is disabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x000000003211877d 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.450186 [ 5753 ] {6b12009e-f5ee-4f71-9bf0-0276999396a8} executeQuery: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35602) (comment: 02883_named_collections_override.sh) (in query: SELECT * FROM url(02883_named_collections_override_test_jfm58sdn_collection1, url='http://127.0.0.1:8123?query=select+2');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000321186e4 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.450348 [ 5753 ] {6b12009e-f5ee-4f71-9bf0-0276999396a8} TCPHandler: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000321186e4 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.481612 [ 5753 ] {a2f666a5-e0f5-4b69-a2a8-0d8ca0f64b50} executeQuery: Code: 36. DB::Exception: Override not allowed because setting allow_override_by_default is disabled. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35602) (comment: 02883_named_collections_override.sh) (in query: SELECT * FROM url(02883_named_collections_override_test_jfm58sdn_collection2, headers('Accept'='text/csv; charset=utf-8'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x000000003211877d 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.481766 [ 5753 ] {a2f666a5-e0f5-4b69-a2a8-0d8ca0f64b50} TCPHandler: Code: 36. DB::Exception: Override not allowed because setting allow_override_by_default is disabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x000000003211877d 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.483473 [ 5753 ] {4576f3d6-94aa-4acf-bda5-bcff316aa056} executeQuery: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35602) (comment: 02883_named_collections_override.sh) (in query: SELECT * FROM url(02883_named_collections_override_test_jfm58sdn_collection2, url='http://127.0.0.1:8123?query=select+2');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000321186e4 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.483590 [ 5753 ] {4576f3d6-94aa-4acf-bda5-bcff316aa056} TCPHandler: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000321186e4 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.485542 [ 5753 ] {8a5e7acb-978a-44e5-97fc-3953485829c2} executeQuery: Code: 36. DB::Exception: Override not allowed for 'format'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35602) (comment: 02883_named_collections_override.sh) (in query: SELECT * FROM url(02883_named_collections_override_test_jfm58sdn_collection2, format='CSV');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000321186e4 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.485677 [ 5753 ] {8a5e7acb-978a-44e5-97fc-3953485829c2} TCPHandler: Code: 36. DB::Exception: Override not allowed for 'format'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000321186e4 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.518150 [ 5753 ] {719674e7-2cda-4777-9f0a-e3c6f3ed3d8b} executeQuery: Code: 36. DB::Exception: Override not allowed for 'format'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35602) (comment: 02883_named_collections_override.sh) (in query: SELECT * FROM url(02883_named_collections_override_test_jfm58sdn_collection3, format='CSV');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000321186e4 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.518270 [ 5753 ] {719674e7-2cda-4777-9f0a-e3c6f3ed3d8b} TCPHandler: Code: 36. DB::Exception: Override not allowed for 'format'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000321186e4 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.546608 [ 5753 ] {c17385d4-68cd-4b8a-9283-7fa0e7a866e7} executeQuery: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35602) (comment: 02883_named_collections_override.sh) (in query: SELECT * FROM url(url_override1, url='http://127.0.0.1:8123?query=select+2');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000321186e4 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.546753 [ 5753 ] {c17385d4-68cd-4b8a-9283-7fa0e7a866e7} TCPHandler: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000321186e4 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.623723 [ 5753 ] {60e997dc-6dfb-4703-b548-56120ae87c10} executeQuery: Code: 36. DB::Exception: Override not allowed because setting allow_override_by_default is disabled. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35602) (comment: 02883_named_collections_override.sh) (in query: SELECT * FROM url(url_override1, headers('Accept'='text/csv; charset=utf-8'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x000000003211877d 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.623884 [ 5753 ] {60e997dc-6dfb-4703-b548-56120ae87c10} TCPHandler: Code: 36. DB::Exception: Override not allowed because setting allow_override_by_default is disabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x000000003211877d 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.625913 [ 5753 ] {84e45995-cbe1-4cdc-a82e-13e727aeccd0} executeQuery: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35602) (comment: 02883_named_collections_override.sh) (in query: SELECT * FROM url(url_override1, url='http://127.0.0.1:8123?query=select+2');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000321186e4 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.626053 [ 5753 ] {84e45995-cbe1-4cdc-a82e-13e727aeccd0} TCPHandler: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000321186e4 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.662186 [ 5753 ] {ee82e15b-4ec6-42d0-affa-4edc59e3f7a8} executeQuery: Code: 36. DB::Exception: Override not allowed because setting allow_override_by_default is disabled. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35602) (comment: 02883_named_collections_override.sh) (in query: SELECT * FROM url(url_override2, headers('Accept'='text/csv; charset=utf-8'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x000000003211877d 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.662362 [ 5753 ] {ee82e15b-4ec6-42d0-affa-4edc59e3f7a8} TCPHandler: Code: 36. DB::Exception: Override not allowed because setting allow_override_by_default is disabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x000000003211877d 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.664477 [ 5753 ] {7953e484-90f5-46c2-9054-b0da307d63c1} executeQuery: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35602) (comment: 02883_named_collections_override.sh) (in query: SELECT * FROM url(url_override2, url='http://127.0.0.1:8123?query=select+2');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000321186e4 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.664681 [ 5753 ] {7953e484-90f5-46c2-9054-b0da307d63c1} TCPHandler: Code: 36. DB::Exception: Override not allowed for 'url'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000321186e4 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.666686 [ 5753 ] {6e032e66-9228-4069-b506-5a8408950832} executeQuery: Code: 36. DB::Exception: Override not allowed for 'format'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35602) (comment: 02883_named_collections_override.sh) (in query: SELECT * FROM url(url_override2, format='CSV');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000321186e4 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.666852 [ 5753 ] {6e032e66-9228-4069-b506-5a8408950832} TCPHandler: Code: 36. DB::Exception: Override not allowed for 'format'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/NamedCollectionsHelpers.cpp:0: DB::tryGetNamedCollectionWithOverrides(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, bool, std::vector>, std::allocator>>>*) @ 0x00000000321186e4 5. ./build_docker/./src/TableFunctions/TableFunctionURL.cpp:0: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4723f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.770603 [ 1658 ] {cecb23d5-3b8c-4656-912d-f43a6285e85f} executeQuery: Code: 497. DB::Exception: user02884_2_test_6b349y97_17103: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_6b349y97.test_table. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:35678) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_6b349y97.test_view_1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:126: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104cf5b 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105882c 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 17. ./build_docker/./src/Storages/StorageView.cpp:169: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000326837a8 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:50.771082 [ 1658 ] {cecb23d5-3b8c-4656-912d-f43a6285e85f} TCPHandler: Code: 497. DB::Exception: user02884_2_test_6b349y97_17103: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_6b349y97.test_table. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:126: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104cf5b 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105882c 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 17. ./build_docker/./src/Storages/StorageView.cpp:169: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000326837a8 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:50.908268 [ 1658 ] {4898a327-bce4-44d9-b403-f42181864912} executeQuery: Code: 36. DB::Exception: Compression codec GCD does not compress anything. You may want to add generic compression algorithm after other transformations, like: GCD, LZ4. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35682) (comment: 02872_gcd_codec.sql) (in query: -- GCD codec can't be used stand-alone CREATE TEMPORARY TABLE table_gcd_codec (n UInt64 CODEC(GCD)) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:207: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307f019b 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.908517 [ 1658 ] {4898a327-bce4-44d9-b403-f42181864912} TCPHandler: Code: 36. DB::Exception: Compression codec GCD does not compress anything. You may want to add generic compression algorithm after other transformations, like: GCD, LZ4. (Note: you can enable setting 'allow_suspicious_codecs' to skip this check). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:207: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307f019b 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.928142 [ 1658 ] {995092ac-10b4-4d57-b1e6-353fc3255dc1} executeQuery: Code: 36. DB::Exception: Codec GCD cannot be applied to column String because it can only be used with Int*, UInt*, Decimal*, Date* or DateTime* types. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35682) (comment: 02872_gcd_codec.sql) (in query: -- GCD codec rejects non-integer/decimal/datetime types CREATE TEMPORARY TABLE table_gcd_codec (str String CODEC(GCD, LZ4)) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Compression/CompressionCodecGCD.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000002f3d3ba1 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:50.928344 [ 1658 ] {995092ac-10b4-4d57-b1e6-353fc3255dc1} TCPHandler: Code: 36. DB::Exception: Codec GCD cannot be applied to column String because it can only be used with Int*, UInt*, Decimal*, Date* or DateTime* types. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Compression/CompressionCodecGCD.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000002f3d3ba1 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:51.404919 [ 6362 ] {be6c8f20-d73a-45be-a5f7-0e47628e67c3} executeQuery: Code: 497. DB::Exception: user02884_2_test_6b349y97_17103: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_6b349y97.test_table. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:35712) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_6b349y97.test_view_4), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:126: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104cf5b 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105882c 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 17. ./build_docker/./src/Storages/StorageView.cpp:169: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000326837a8 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:51.405257 [ 6362 ] {be6c8f20-d73a-45be-a5f7-0e47628e67c3} TCPHandler: Code: 497. DB::Exception: user02884_2_test_6b349y97_17103: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_6b349y97.test_table. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:126: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104cf5b 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105882c 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 17. ./build_docker/./src/Storages/StorageView.cpp:169: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000326837a8 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:51.435578 [ 1658 ] {f96489a8-20ce-4475-bd36-9b28f235112e} executeQuery: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35708) (comment: 02869_insert_filenames_collisions.sql) (in query: CREATE TABLE t_collisions (`very_very_long_column_name_that_will_be_replaced_with_hash` Int32, `e798545eefc8b7a1c2c81ff00c064ad8` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS replace_long_file_name_to_hash = 1, max_file_name_length = 42, index_granularity = 50472, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 288074012, compact_parts_max_granules_to_buffer = 83, compact_parts_merge_max_bytes_to_prefetch_part = 31981506, merge_max_block_size = 10630, old_parts_lifetime = 243., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 39, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26001710, concurrent_part_removal_threshold = 84, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 51614, primary_key_compress_block_size = 8259), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7054: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000032aeb699 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:411: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5bc0 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 8. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 10. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:51.435877 [ 1658 ] {f96489a8-20ce-4475-bd36-9b28f235112e} TCPHandler: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7054: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000032aeb699 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:411: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5bc0 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 8. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 10. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:51.461195 [ 1658 ] {d3a27130-ce75-42a6-ac7d-438c6acc8a7d} executeQuery: Code: 36. DB::Exception: Columns 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' and 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' have streams (very_very_long_column_name_that_will_be_replaced_with_hash and e798545eefc8b7a1c2c81ff00c064ad8) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35708) (comment: 02869_insert_filenames_collisions.sql) (in query: ALTER TABLE t_collisions ADD COLUMN very_very_long_column_name_that_will_be_replaced_with_hash Int32;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7054: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000032aeb699 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000032b4bb26 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3409: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40b5e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:51.461425 [ 1658 ] {d3a27130-ce75-42a6-ac7d-438c6acc8a7d} TCPHandler: Code: 36. DB::Exception: Columns 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' and 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' have streams (very_very_long_column_name_that_will_be_replaced_with_hash and e798545eefc8b7a1c2c81ff00c064ad8) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7054: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000032aeb699 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000032b4bb26 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3409: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40b5e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:51.463237 [ 1658 ] {1862caf9-a758-4d4d-8e53-89cf983f7245} executeQuery: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35708) (comment: 02869_insert_filenames_collisions.sql) (in query: ALTER TABLE t_collisions RENAME COLUMN col1 TO very_very_long_column_name_that_will_be_replaced_with_hash;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7054: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000032aeb699 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000032b4bb26 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3409: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40b5e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:51.463426 [ 1658 ] {1862caf9-a758-4d4d-8e53-89cf983f7245} TCPHandler: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7054: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000032aeb699 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000032b4bb26 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3409: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40b5e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:51.478220 [ 1658 ] {b1a26d4b-e3df-4729-bee3-20281824fd3c} executeQuery: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35708) (comment: 02869_insert_filenames_collisions.sql) (in query: ALTER TABLE t_collisions MODIFY SETTING replace_long_file_name_to_hash = 1, max_file_name_length = 42;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7054: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000032aeb699 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000032b4bb26 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3409: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40b5e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:51.478330 [ 1658 ] {b1a26d4b-e3df-4729-bee3-20281824fd3c} TCPHandler: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7054: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000032aeb699 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000032b4bb26 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3409: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40b5e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:51.503812 [ 1658 ] {87c38cc8-14ad-4312-a5fc-2440bf78fbec} executeQuery: Code: 36. DB::Exception: Columns 'col Nested(s LowCardinality(String), u LowCardinality(String))' and 'col Array(String)' have streams (col.size0 and col.size0) with collision in file name col.size0. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35708) (comment: 02869_insert_filenames_collisions.sql) (in query: CREATE TABLE t_collisions (`id` Int, `col` Array(String), `col.s` Array(LowCardinality(String)), `col.u` Array(LowCardinality(String))) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 50472, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 288074012, compact_parts_max_granules_to_buffer = 83, compact_parts_merge_max_bytes_to_prefetch_part = 31981506, merge_max_block_size = 10630, old_parts_lifetime = 243., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 39, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26001710, concurrent_part_removal_threshold = 84, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 51614, primary_key_compress_block_size = 8259), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7054: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000032aeb699 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:411: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5bc0 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 8. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 10. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:51.503937 [ 1658 ] {87c38cc8-14ad-4312-a5fc-2440bf78fbec} TCPHandler: Code: 36. DB::Exception: Columns 'col Nested(s LowCardinality(String), u LowCardinality(String))' and 'col Array(String)' have streams (col.size0 and col.size0) with collision in file name col.size0. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7054: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000032aeb699 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:411: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5bc0 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 8. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 10. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:51.509689 [ 1658 ] {a863adba-26ea-44ba-ba98-3a866f504bc0} executeQuery: Code: 36. DB::Exception: Columns 'col Nested(s LowCardinality(String), u LowCardinality(String))' and 'col Array(String)' have streams (col.size0 and col.size0) with collision in file name col.size0. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:35708) (comment: 02869_insert_filenames_collisions.sql) (in query: ALTER TABLE t_collisions MODIFY COLUMN col Array(String);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7054: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000032aeb699 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000032b4bb26 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3409: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40b5e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:51.509789 [ 1658 ] {a863adba-26ea-44ba-ba98-3a866f504bc0} TCPHandler: Code: 36. DB::Exception: Columns 'col Nested(s LowCardinality(String), u LowCardinality(String))' and 'col Array(String)' have streams (col.size0 and col.size0) with collision in file name col.size0. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7054: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000032aeb699 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x0000000032b4bb26 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3409: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40b5e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:51.599399 [ 731 ] {48058e5c-84d8-4c1b-9528-ae24bc9fe5a5} executeQuery: Code: 497. DB::Exception: user02884_2_test_6b349y97_17103: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_6b349y97.test_table. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:35736) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_6b349y97.test_view_5), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:126: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104cf5b 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105882c 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 17. ./build_docker/./src/Storages/StorageView.cpp:169: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000326837a8 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:51.599737 [ 731 ] {48058e5c-84d8-4c1b-9528-ae24bc9fe5a5} TCPHandler: Code: 497. DB::Exception: user02884_2_test_6b349y97_17103: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_6b349y97.test_table. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:126: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104cf5b 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105882c 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 17. ./build_docker/./src/Storages/StorageView.cpp:169: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000326837a8 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:52.207321 [ 1579 ] {57f9603f-0d55-4416-9747-dd259b2de469} executeQuery: Code: 497. DB::Exception: user02884_3_test_6b349y97_1159: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_6b349y97.test_table. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:35828) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_6b349y97.test_view_8), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:126: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104cf5b 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105882c 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 17. ./build_docker/./src/Storages/StorageView.cpp:169: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000326837a8 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:52.207666 [ 1579 ] {57f9603f-0d55-4416-9747-dd259b2de469} TCPHandler: Code: 497. DB::Exception: user02884_3_test_6b349y97_1159: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_6b349y97.test_table. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:126: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104cf5b 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105882c 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 17. ./build_docker/./src/Storages/StorageView.cpp:169: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000326837a8 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:53.276534 [ 731 ] {bf0b8f3c-97b7-4bbd-9936-1dc785207146} executeQuery: Code: 497. DB::Exception: user02884_2_test_6b349y97_17103: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_6b349y97.test_table. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:35912) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_6b349y97.test_view_10), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:126: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104cf5b 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105882c 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 17. ./build_docker/./src/Storages/StorageView.cpp:169: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000326837a8 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:53.276958 [ 731 ] {bf0b8f3c-97b7-4bbd-9936-1dc785207146} TCPHandler: Code: 497. DB::Exception: user02884_2_test_6b349y97_17103: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_6b349y97.test_table. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:126: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104cf5b 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105882c 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 17. ./build_docker/./src/Storages/StorageView.cpp:169: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000326837a8 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 20. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:53.683862 [ 731 ] {511e3d9f-98f4-4088-9eed-4a23f04b3172} executeQuery: Code: 43. DB::Exception: Provided time zone must be non-empty: while executing 'FUNCTION formatDateTime(_CAST(1692977400_Nullable(DateTime('UTC')), 'Nullable(DateTime('UTC'))'_String) :: 1, '%H%i%S'_String :: 2, toString(if(modulo(__table1.number, 2_UInt8), _CAST(''_String, 'Enum8(\'\' = 1, \'Europe/Amsterdam\' = 2)'_String), _CAST('Europe/Amsterdam'_String, 'Enum8(\'\' = 1, \'Europe/Amsterdam\' = 2)'_String))) :: 5) -> formatDateTime(_CAST(1692977400_Nullable(DateTime('UTC')), 'Nullable(DateTime('UTC'))'_String), '%H%i%S'_String, toString(if(modulo(__table1.number, 2_UInt8), _CAST(''_String, 'Enum8(\'\' = 1, \'Europe/Amsterdam\' = 2)'_String), _CAST('Europe/Amsterdam'_String, 'Enum8(\'\' = 1, \'Europe/Amsterdam\' = 2)'_String)))) Nullable(String) : 3'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:35970) (comment: 02863_non_const_timezone_check.sql) (in query: SELECT formatDateTime((SELECT materialize(date) FROM Dates), '%H%i%S', number % 2 ? '' : 'Europe/Amsterdam') FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b897691 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForNulls(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83fc8b 8. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f6d1 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:53.684028 [ 731 ] {511e3d9f-98f4-4088-9eed-4a23f04b3172} TCPHandler: Code: 43. DB::Exception: Provided time zone must be non-empty: while executing 'FUNCTION formatDateTime(_CAST(1692977400_Nullable(DateTime('UTC')), 'Nullable(DateTime('UTC'))'_String) :: 1, '%H%i%S'_String :: 2, toString(if(modulo(__table1.number, 2_UInt8), _CAST(''_String, 'Enum8(\'\' = 1, \'Europe/Amsterdam\' = 2)'_String), _CAST('Europe/Amsterdam'_String, 'Enum8(\'\' = 1, \'Europe/Amsterdam\' = 2)'_String))) :: 5) -> formatDateTime(_CAST(1692977400_Nullable(DateTime('UTC')), 'Nullable(DateTime('UTC'))'_String), '%H%i%S'_String, toString(if(modulo(__table1.number, 2_UInt8), _CAST(''_String, 'Enum8(\'\' = 1, \'Europe/Amsterdam\' = 2)'_String), _CAST('Europe/Amsterdam'_String, 'Enum8(\'\' = 1, \'Europe/Amsterdam\' = 2)'_String)))) Nullable(String) : 3'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b897691 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForNulls(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83fc8b 8. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f6d1 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:53.739245 [ 731 ] {160cee92-136a-447a-9980-133d7e6a6a31} executeQuery: Code: 43. DB::Exception: Provided time zone must be non-empty: while executing 'FUNCTION toString(_CAST(1692977400_Nullable(DateTime('UTC')), 'Nullable(DateTime('UTC'))'_String) :: 1, toString(if(modulo(__table1.number, 2_UInt8), _CAST('America/Los_Angeles'_String, 'Enum8(\'\' = 1, \'America/Los_Angeles\' = 2)'_String), _CAST(''_String, 'Enum8(\'\' = 1, \'America/Los_Angeles\' = 2)'_String))) :: 4) -> toString(_CAST(1692977400_Nullable(DateTime('UTC')), 'Nullable(DateTime('UTC'))'_String), toString(if(modulo(__table1.number, 2_UInt8), _CAST('America/Los_Angeles'_String, 'Enum8(\'\' = 1, \'America/Los_Angeles\' = 2)'_String), _CAST(''_String, 'Enum8(\'\' = 1, \'America/Los_Angeles\' = 2)'_String)))) Nullable(String) : 2'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:35970) (comment: 02863_non_const_timezone_check.sql) (in query: SELECT toString((SELECT materialize(date) FROM Dates), number % 2 ? 'America/Los_Angeles' : '') FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018536a2f 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018522093 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:53.739720 [ 731 ] {160cee92-136a-447a-9980-133d7e6a6a31} TCPHandler: Code: 43. DB::Exception: Provided time zone must be non-empty: while executing 'FUNCTION toString(_CAST(1692977400_Nullable(DateTime('UTC')), 'Nullable(DateTime('UTC'))'_String) :: 1, toString(if(modulo(__table1.number, 2_UInt8), _CAST('America/Los_Angeles'_String, 'Enum8(\'\' = 1, \'America/Los_Angeles\' = 2)'_String), _CAST(''_String, 'Enum8(\'\' = 1, \'America/Los_Angeles\' = 2)'_String))) :: 4) -> toString(_CAST(1692977400_Nullable(DateTime('UTC')), 'Nullable(DateTime('UTC'))'_String), toString(if(modulo(__table1.number, 2_UInt8), _CAST('America/Los_Angeles'_String, 'Enum8(\'\' = 1, \'America/Los_Angeles\' = 2)'_String), _CAST(''_String, 'Enum8(\'\' = 1, \'America/Los_Angeles\' = 2)'_String)))) Nullable(String) : 2'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018536a2f 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018522093 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:53.890629 [ 1579 ] {} TCPHandler: Code: 702. DB::Exception: Client info's client_name does not match: ClickHouse client not equal to Hacker client. (CLIENT_INFO_DOES_NOT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Server/TCPHandler.cpp:162: DB::TCPHandler::receiveQuery() @ 0x00000000334b6e8d 5. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003349bca4 6. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:53.891815 [ 1579 ] {} TCPHandler: Can't skip data packets after query failure. 2025.03.05 21:08:53.909293 [ 1579 ] {} TCPHandler: Code: 702. DB::Exception: Client info's version does not match: 20.13.0 (54443) not equal to 16.13.1 (54443). (CLIENT_INFO_DOES_NOT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x00000000334bbcc5 5. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003349bca4 6. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:53.909973 [ 1579 ] {} TCPHandler: Can't skip data packets after query failure. 2025.03.05 21:08:53.987708 [ 731 ] {7ae34063-ffb7-48ac-bb04-72d5703bfc64} executeQuery: Code: 397. DB::Exception: SQL SECURITY INVOKER can't be specified for MATERIALIZED VIEW. (QUERY_IS_NOT_SUPPORTED_IN_MATERIALIZED_VIEW) (version 24.3.12.76.altinitystable) (from [::1]:36170) (comment: 02884_create_view_with_sql_security_option.sh) (in query: CREATE MATERIALIZED VIEW test_6b349y97.test_mv_2 (s String) ENGINE = MergeTree ORDER BY s SQL SECURITY INVOKER AS SELECT * FROM test_6b349y97.test_table; ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x00000000322e1871 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000322f4d97 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000322f4aca 7. ./build_docker/./src/Storages/StorageMaterializedView.cpp:694: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000322f29af 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:53.988120 [ 731 ] {7ae34063-ffb7-48ac-bb04-72d5703bfc64} TCPHandler: Code: 397. DB::Exception: SQL SECURITY INVOKER can't be specified for MATERIALIZED VIEW. (QUERY_IS_NOT_SUPPORTED_IN_MATERIALIZED_VIEW), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x00000000322e1871 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&>(std::allocator, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000322f4d97 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000322f4aca 7. ./build_docker/./src/Storages/StorageMaterializedView.cpp:694: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000322f29af 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:54.626136 [ 5863 ] {1a0f8560-e27e-45db-8b5f-c396ca263e3d} executeQuery: Code: 35. DB::Exception: Number of arguments for function "and" should be at least 2: passed 1: In scope SELECT b FROM set_index__fuzz_41 WHERE and(b = 256) SETTINGS force_data_skipping_indices = 'b_set', optimize_move_to_prewhere = 0, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, allow_experimental_parallel_reading_from_replicas = 2. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.3.12.76.altinitystable) (from [::1]:36430) (comment: 02861_index_set_incorrect_args.sql) (in query: SELECT b FROM set_index__fuzz_41 WHERE and(b = 256) SETTINGS force_data_skipping_indices = 'b_set', optimize_move_to_prewhere = 0, max_parallel_replicas=2, parallel_replicas_for_non_replicated_merge_tree=1, allow_experimental_parallel_reading_from_replicas=2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000001806a053 4. ./build_docker/./src/Functions/FunctionsLogical.cpp:0: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002e8c062e 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:54.626544 [ 5863 ] {1a0f8560-e27e-45db-8b5f-c396ca263e3d} TCPHandler: Code: 35. DB::Exception: Number of arguments for function "and" should be at least 2: passed 1: In scope SELECT b FROM set_index__fuzz_41 WHERE and(b = 256) SETTINGS force_data_skipping_indices = 'b_set', optimize_move_to_prewhere = 0, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, allow_experimental_parallel_reading_from_replicas = 2. (TOO_FEW_ARGUMENTS_FOR_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000001806a053 4. ./build_docker/./src/Functions/FunctionsLogical.cpp:0: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002e8c062e 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:56.686730 [ 5863 ] {2bf1419d-a7f9-4481-8b57-80e89ef8e6bf} executeQuery: Code: 42. DB::Exception: Table name was not found in function arguments. Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:37388) (comment: 02841_remote_parameter_parsing_error.sql) (in query: select * from remote('127.0.0.1', sys);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&&) @ 0x000000002e43796b 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e43402b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:56.687067 [ 5863 ] {2bf1419d-a7f9-4481-8b57-80e89ef8e6bf} TCPHandler: Code: 42. DB::Exception: Table name was not found in function arguments. Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&&) @ 0x000000002e43796b 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e43402b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:56.690236 [ 5863 ] {60123612-2f30-450f-8a4c-d517a8b17327} executeQuery: Code: 42. DB::Exception: Table name was not found in function arguments. Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:37388) (comment: 02841_remote_parameter_parsing_error.sql) (in query: select * from remote('127.0.0.1', system);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&&) @ 0x000000002e43796b 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e43402b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:56.690426 [ 5863 ] {60123612-2f30-450f-8a4c-d517a8b17327} TCPHandler: Code: 42. DB::Exception: Table name was not found in function arguments. Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&&) @ 0x000000002e43796b 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e43402b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:56.734105 [ 5863 ] {ccdcdb45-7d21-4454-a95a-629d32b99665} executeQuery: Code: 60. DB::Exception: Table system.o does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:37388) (comment: 02841_remote_parameter_parsing_error.sql) (in query: select * from remote('127.0.0.1', system.o);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:53: DB::getStructureOfRemoteTableInShard(DB::Cluster const&, DB::Cluster::ShardInfo const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x00000000326b45f0 8. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:0: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x00000000326b7bb1 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e43605a 10. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e434db0 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 12. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:56.734406 [ 5863 ] {ccdcdb45-7d21-4454-a95a-629d32b99665} TCPHandler: Code: 60. DB::Exception: Table system.o does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:53: DB::getStructureOfRemoteTableInShard(DB::Cluster const&, DB::Cluster::ShardInfo const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x00000000326b45f0 8. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:0: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x00000000326b7bb1 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e43605a 10. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e434db0 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 12. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:08:56.777503 [ 5863 ] {47eae6e7-c277-4445-a348-cb5b93bed9cc} executeQuery: Code: 47. DB::Exception: Missing columns: 'default' while processing query: 'default', required columns: 'default' 'default'. (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:37388) (comment: 02841_remote_parameter_parsing_error.sql) (in query: select * from remote('127.0.0.1', system.one, default);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x00000000315b73f2 5. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1509: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000315c774b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:222: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x000000003218bf12 7. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr) @ 0x000000003218837f 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageDistributed* std::construct_at[abi:v15000]&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, DB::StorageDistributed*>(DB::StorageDistributed*, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&) @ 0x000000002e43b826 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&>(std::allocator, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&) @ 0x000000002e43b4f4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, void>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&) @ 0x000000002e43b221 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e435608 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:56.777847 [ 5863 ] {47eae6e7-c277-4445-a348-cb5b93bed9cc} TCPHandler: Code: 47. DB::Exception: Missing columns: 'default' while processing query: 'default', required columns: 'default' 'default'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x00000000315b73f2 5. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1509: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000315c774b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:222: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x000000003218bf12 7. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr) @ 0x000000003218837f 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageDistributed* std::construct_at[abi:v15000]&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, DB::StorageDistributed*>(DB::StorageDistributed*, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&) @ 0x000000002e43b826 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&>(std::allocator, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&) @ 0x000000002e43b4f4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, void>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&) @ 0x000000002e43b221 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e435608 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:56.808036 [ 5863 ] {4f084b32-7a10-46a6-8b1e-e67a8da0c172} executeQuery: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37388) (comment: 02841_remote_parameter_parsing_error.sql) (in query: SELECT * FROM remote('127.0.0.1', system.one, default, '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e433db5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:56.808292 [ 5863 ] {4f084b32-7a10-46a6-8b1e-e67a8da0c172} TCPHandler: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e433db5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:56.810321 [ 5863 ] {94071cca-83fa-49b7-aada-c66fa23cc613} executeQuery: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37388) (comment: 02841_remote_parameter_parsing_error.sql) (in query: select * from remote('127.0.0.1', system.one, default, key1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e433db5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:56.810436 [ 5863 ] {94071cca-83fa-49b7-aada-c66fa23cc613} TCPHandler: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e433db5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:56.812186 [ 5863 ] {edae3fac-4989-4f31-9f40-292ba35afd39} executeQuery: Code: 47. DB::Exception: Missing columns: 'key1' while processing query: 'key1', required columns: 'key1' 'key1'. (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:37388) (comment: 02841_remote_parameter_parsing_error.sql) (in query: SELECT * FROM remote('127.0.0.1', system.one, 'default', '[HIDDEN]', key1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x00000000315b73f2 5. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1509: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000315c774b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:222: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x000000003218bf12 7. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr) @ 0x000000003218837f 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageDistributed* std::construct_at[abi:v15000]&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, DB::StorageDistributed*>(DB::StorageDistributed*, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&) @ 0x000000002e43b826 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&>(std::allocator, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&) @ 0x000000002e43b4f4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, void>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&) @ 0x000000002e43b221 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e435608 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:56.812312 [ 5863 ] {edae3fac-4989-4f31-9f40-292ba35afd39} TCPHandler: Code: 47. DB::Exception: Missing columns: 'key1' while processing query: 'key1', required columns: 'key1' 'key1'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x00000000315b73f2 5. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1509: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000315c774b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:222: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x000000003218bf12 7. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr) @ 0x000000003218837f 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageDistributed* std::construct_at[abi:v15000]&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, DB::StorageDistributed*>(DB::StorageDistributed*, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&) @ 0x000000002e43b826 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&>(std::allocator, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&) @ 0x000000002e43b4f4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, void>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&) @ 0x000000002e43b221 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e435608 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:08:56.813601 [ 5863 ] {3f733e18-d26e-4dc7-940e-6dbab901dffe} executeQuery: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37388) (comment: 02841_remote_parameter_parsing_error.sql) (in query: SELECT * FROM remote('127.0.0.1', system.one, default, '[HIDDEN]', key1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e433db5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:56.813731 [ 5863 ] {3f733e18-d26e-4dc7-940e-6dbab901dffe} TCPHandler: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e433db5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:56.814962 [ 5863 ] {d3304a96-fe8c-4de8-98e6-ed45d00775f8} executeQuery: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37388) (comment: 02841_remote_parameter_parsing_error.sql) (in query: select * from remote('127.0.0.1', system.one, 'default', pwd, key1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e433db5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:56.815068 [ 5863 ] {d3304a96-fe8c-4de8-98e6-ed45d00775f8} TCPHandler: Code: 36. DB::Exception: Arguments `user` and `password` should be string literals (in single quotes). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e433db5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:56.834780 [ 5863 ] {1e60d368-1f76-4f1e-9b3a-5269a2298662} executeQuery: Code: 42. DB::Exception: Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:37388) (comment: 02841_remote_parameter_parsing_error.sql) (in query: SELECT * FROM remote('127.0.0.1', system.one, 'default', '[HIDDEN]', key1, key2)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002e437716 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e433885 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:56.834994 [ 5863 ] {1e60d368-1f76-4f1e-9b3a-5269a2298662} TCPHandler: Code: 42. DB::Exception: Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002e437716 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e433885 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:56.855038 [ 5863 ] {82bd16b2-52cd-4ce9-9692-a56127330211} executeQuery: Code: 42. DB::Exception: Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:37388) (comment: 02841_remote_parameter_parsing_error.sql) (in query: SELECT * FROM remote('127.0.0.1', system, one, 'default', '[HIDDEN]', key1, key2)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002e437716 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e430e1a 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:56.855273 [ 5863 ] {82bd16b2-52cd-4ce9-9692-a56127330211} TCPHandler: Code: 42. DB::Exception: Table function 'remote' requires from 1 to 6 parameters: [, , ] [, username[, password], sharding_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002e437716 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e430e1a 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:57.501752 [ 10508 ] {cd2b3eac-396e-4c58-8eb8-cc964c9ef5f8} executeQuery: Code: 497. DB::Exception: user02884_1_test_6b349y97_6475: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_6b349y97.test_mv_data. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:37694) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_6b349y97.test_mv_4), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Storages/StorageMaterializedView.cpp:223: DB::StorageMaterializedView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000322e5d68 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:57.506833 [ 10508 ] {cd2b3eac-396e-4c58-8eb8-cc964c9ef5f8} TCPHandler: Code: 497. DB::Exception: user02884_1_test_6b349y97_6475: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_6b349y97.test_mv_data. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Storages/StorageMaterializedView.cpp:223: DB::StorageMaterializedView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000322e5d68 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:57.746989 [ 5753 ] {56a6bb1f-c499-468b-a886-0cb68605fae1} PushingToViews: Failed to push block to view test_6b349y97.test_mv_4 (7254acc7-5351-4dea-b3c7-1a7e3a81107a), user02884_1_test_6b349y97_6475: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(s) ON test_6b349y97.test_mv_data 2025.03.05 21:08:57.772689 [ 5753 ] {56a6bb1f-c499-468b-a886-0cb68605fae1} executeQuery: Code: 497. DB::Exception: user02884_1_test_6b349y97_6475: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(s) ON test_6b349y97.test_mv_data. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:37800) (comment: 02884_create_view_with_sql_security_option.sh) (in query: INSERT INTO test_6b349y97.test_table VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x0000000030f3364e 10. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000033c9c25b 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033c9f541 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 13. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:57.774018 [ 5753 ] {56a6bb1f-c499-468b-a886-0cb68605fae1} TCPHandler: Code: 497. DB::Exception: user02884_1_test_6b349y97_6475: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(s) ON test_6b349y97.test_mv_data. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x0000000030f3364e 10. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000033c9c25b 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033c9f541 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 13. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:58.007246 [ 5753 ] {c9458892-1fbf-4238-a171-d6b643952344} PushingToViews: Failed to push block to view test_6b349y97.test_mv_4 (7254acc7-5351-4dea-b3c7-1a7e3a81107a), user02884_1_test_6b349y97_6475: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(s) ON test_6b349y97.test_mv_data 2025.03.05 21:08:59.310265 [ 10508 ] {75e71062-9e2a-4b8e-ba2b-6080be21867c} executeQuery: Code: 497. DB::Exception: user02884_1_test_6b349y97_6475: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_6b349y97.test_table. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:51468) (comment: 02884_create_view_with_sql_security_option.sh) (in query: SELECT * FROM test_6b349y97.test_mv_4), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Storages/StorageMaterializedView.cpp:214: DB::StorageMaterializedView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000322e5abd 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.310827 [ 10508 ] {75e71062-9e2a-4b8e-ba2b-6080be21867c} TCPHandler: Code: 497. DB::Exception: user02884_1_test_6b349y97_6475: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_6b349y97.test_table. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Storages/StorageMaterializedView.cpp:214: DB::StorageMaterializedView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000322e5abd 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.535571 [ 10241 ] {39104045-673f-4029-b2ce-7641915dfe47} PushingToViews: Failed to push block to view test_6b349y97.test_mv_4 (7254acc7-5351-4dea-b3c7-1a7e3a81107a), user02884_1_test_6b349y97_6475: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_6b349y97.test_table 2025.03.05 21:08:59.563067 [ 10241 ] {39104045-673f-4029-b2ce-7641915dfe47} executeQuery: Code: 497. DB::Exception: user02884_1_test_6b349y97_6475: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_6b349y97.test_table. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:51490) (comment: 02884_create_view_with_sql_security_option.sh) (in query: INSERT INTO test_6b349y97.test_table VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:126: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104cf5b 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:216: DB::InterpreterSelectQueryAnalyzer::getSampleBlock() @ 0x0000000030ffffc1 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000030fffedd 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000033c9adc4 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033c9f541 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 17. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.563452 [ 10241 ] {39104045-673f-4029-b2ce-7641915dfe47} TCPHandler: Code: 497. DB::Exception: user02884_1_test_6b349y97_6475: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_6b349y97.test_table. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:126: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104cf5b 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:216: DB::InterpreterSelectQueryAnalyzer::getSampleBlock() @ 0x0000000030ffffc1 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000030fffedd 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000033c9adc4 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033c9f541 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 17. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.738542 [ 10241 ] {b9c9c84c-773c-48aa-a0d0-df8cdb0179de} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_aliases' in scope alias2 AS (SELECT number FROM test_aliases). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:51498) (comment: 02834_analyzer_with_statement_references.sql) (in query: WITH test_aliases AS (SELECT number FROM numbers(20)), alias2 AS (SELECT number FROM test_aliases) SELECT number FROM alias2 SETTINGS enable_global_with_statement = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6519: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882639 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7911: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd42 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.738819 [ 10241 ] {b9c9c84c-773c-48aa-a0d0-df8cdb0179de} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_aliases' in scope alias2 AS (SELECT number FROM test_aliases). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6519: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882639 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7911: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd42 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.789311 [ 10508 ] {dd8731ae-72fe-4c5b-9976-9a27c85c3cc9} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50028) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.789837 [ 10508 ] {dd8731ae-72fe-4c5b-9976-9a27c85c3cc9} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:59.799277 [ 10508 ] {895da629-e694-4cbb-bff8-54e715af3827} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50036) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.799471 [ 10508 ] {895da629-e694-4cbb-bff8-54e715af3827} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:59.809162 [ 10508 ] {98f86c09-d91c-41cc-944f-f7ccebc10825} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50050) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompact settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.809628 [ 10508 ] {98f86c09-d91c-41cc-944f-f7ccebc10825} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:59.818880 [ 10508 ] {129e22ce-cf6e-4426-9895-bfd71bf31496} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50052) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompactEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.819171 [ 10508 ] {129e22ce-cf6e-4426-9895-bfd71bf31496} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:59.829108 [ 10241 ] {5e290cd9-a452-4b78-8d6a-8420d5145545} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50054) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONObjectEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.829369 [ 10241 ] {5e290cd9-a452-4b78-8d6a-8420d5145545} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:59.837897 [ 10241 ] {03fd9f7b-d2b2-4b86-bc82-7208ea2262c7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50062) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format XML settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.838247 [ 10241 ] {03fd9f7b-d2b2-4b86-bc82-7208ea2262c7} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:59.849768 [ 10241 ] {39523a38-5da5-476e-8200-32e898cfb39f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50076) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.850144 [ 10241 ] {39523a38-5da5-476e-8200-32e898cfb39f} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:59.859623 [ 10241 ] {2c6eb231-4723-4ada-9cd3-9111933a5e2b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50092) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.859880 [ 10241 ] {2c6eb231-4723-4ada-9cd3-9111933a5e2b} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:59.868811 [ 10241 ] {2d571cd2-fbab-4a33-b7b0-22cbe498f5ef} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50106) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompact settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.869238 [ 10241 ] {2d571cd2-fbab-4a33-b7b0-22cbe498f5ef} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:59.877693 [ 10241 ] {5916a0d1-8d3e-4107-b12d-e6ced2ad72fd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50110) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompactEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.878000 [ 10241 ] {5916a0d1-8d3e-4107-b12d-e6ced2ad72fd} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:59.888586 [ 10241 ] {b9531695-27c3-47ac-a4c3-4ebb4b72754b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50118) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONObjectEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.888963 [ 10241 ] {b9531695-27c3-47ac-a4c3-4ebb4b72754b} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:59.898269 [ 10241 ] {b656382a-eacf-46c5-8637-b6ee0e08e149} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50128) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format XML settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.898739 [ 10241 ] {b656382a-eacf-46c5-8637-b6ee0e08e149} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:59.908521 [ 10241 ] {e0c4c4b8-dfe7-4c38-8970-599c2407135c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50132) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSON settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.908777 [ 10241 ] {e0c4c4b8-dfe7-4c38-8970-599c2407135c} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:59.917252 [ 10241 ] {58e576e9-d6b9-4c97-a68c-46219e3c7087} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50142) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONEachRow settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.917429 [ 10241 ] {58e576e9-d6b9-4c97-a68c-46219e3c7087} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:59.926612 [ 10241 ] {f478990f-f5c5-42f8-b251-81424cca5eeb} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50158) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompact settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.926923 [ 10241 ] {f478990f-f5c5-42f8-b251-81424cca5eeb} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:59.936075 [ 10241 ] {1a33e13d-4ad7-44fb-b064-ea90dbb3ccbd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50160) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompactEachRow settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.936350 [ 10241 ] {1a33e13d-4ad7-44fb-b064-ea90dbb3ccbd} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:59.968067 [ 10508 ] {813e2c39-2b1e-4411-accb-b7bfeecd0e00} executeQuery: Code: 497. DB::Exception: user02884_2_test_6b349y97_17103: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(a) ON test_6b349y97.source. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:51522) (comment: 02884_create_view_with_sql_security_option.sh) (in query: INSERT INTO source SELECT * FROM generateRandom() LIMIT 100), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000030f3617b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.968095 [ 10241 ] {95333632-580a-4054-9bf6-10f84f78f998} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50166) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONObjectEachRow settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.968510 [ 10241 ] {95333632-580a-4054-9bf6-10f84f78f998} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:59.968561 [ 10508 ] {813e2c39-2b1e-4411-accb-b7bfeecd0e00} TCPHandler: Code: 497. DB::Exception: user02884_2_test_6b349y97_17103: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(a) ON test_6b349y97.source. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed79b0b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002ed78528 6. ./build_docker/./src/Access/ContextAccess.cpp:729: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002ed2b1b7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002fc97cf7 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002fc4e8c9 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000030f3617b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.978600 [ 10241 ] {c42a80a2-3fcf-4c5e-be8f-73a01d89e9e3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50172) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format XML settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.978916 [ 10241 ] {c42a80a2-3fcf-4c5e-be8f-73a01d89e9e3} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:08:59.989608 [ 10241 ] {a2af010c-0239-44fb-ac14-234de7876c94} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50182) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSON settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:08:59.990003 [ 10241 ] {a2af010c-0239-44fb-ac14-234de7876c94} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:00.198925 [ 10508 ] {793bca95-731c-4f26-9596-61c93bd80e7d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50194) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompact settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.199314 [ 10508 ] {793bca95-731c-4f26-9596-61c93bd80e7d} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:00.403057 [ 10508 ] {03d1625e-8648-486f-9cfa-b60993b4071c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50208) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONObjectEachRow settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.403525 [ 10508 ] {03d1625e-8648-486f-9cfa-b60993b4071c} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:00.605785 [ 10241 ] {6e745bfe-d93f-4cc9-a9ff-d608f0d512e7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50218) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONEachRow settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.606091 [ 10241 ] {6e745bfe-d93f-4cc9-a9ff-d608f0d512e7} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:00.622110 [ 5753 ] {ca15c228-b745-407b-850e-2e5500630101} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 1, should be 2: In scope SELECT addDate(CAST('2022-05-07', 'Date')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:51586) (comment: 02834_add_sub_date_functions.sql) (in query: SELECT addDate('2022-05-07'::Date);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.622248 [ 5753 ] {ca15c228-b745-407b-850e-2e5500630101} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 1, should be 2: In scope SELECT addDate(CAST('2022-05-07', 'Date')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.623944 [ 5753 ] {04e4e421-3319-4fd3-86f3-c2b8dd9a5f46} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate(CAST('2022-05-07', 'Date'), toIntervalMinute(5), 5). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:51586) (comment: 02834_add_sub_date_functions.sql) (in query: SELECT addDate('2022-05-07'::Date, INTERVAL 5 MINUTE, 5);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.624078 [ 5753 ] {04e4e421-3319-4fd3-86f3-c2b8dd9a5f46} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate(CAST('2022-05-07', 'Date'), toIntervalMinute(5), 5). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.651262 [ 5753 ] {2daea4df-3013-4eff-a76c-e590009f9c05} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of 2nd argument of function addDate. Should be an interval: In scope SELECT addDate(CAST('2022-05-07', 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:51586) (comment: 02834_add_sub_date_functions.sql) (in query: SELECT addDate('2022-05-07'::Date, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionOpDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000190e7ee6 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.651478 [ 5753 ] {2daea4df-3013-4eff-a76c-e590009f9c05} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of 2nd argument of function addDate. Should be an interval: In scope SELECT addDate(CAST('2022-05-07', 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionOpDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000190e7ee6 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.676233 [ 5753 ] {0ee8eb62-66a4-4816-bcaf-58787d2f1e33} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of 1st argument of function addDate. Should be a date, a date with time or a string: In scope SELECT addDate(1.2, toIntervalMinute(5)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:51586) (comment: 02834_add_sub_date_functions.sql) (in query: SELECT addDate(1.2, INTERVAL 5 MINUTE);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionOpDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000190e817d 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.676454 [ 5753 ] {0ee8eb62-66a4-4816-bcaf-58787d2f1e33} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of 1st argument of function addDate. Should be a date, a date with time or a string: In scope SELECT addDate(1.2, toIntervalMinute(5)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionOpDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000190e817d 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.695377 [ 5753 ] {36678afb-9ece-4d4a-bb50-1f2f9cde8332} executeQuery: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 1, should be 2: In scope SELECT subDate(CAST('2022-05-07', 'Date')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:51586) (comment: 02834_add_sub_date_functions.sql) (in query: SELECT subDate('2022-05-07'::Date);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.695517 [ 5753 ] {36678afb-9ece-4d4a-bb50-1f2f9cde8332} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 1, should be 2: In scope SELECT subDate(CAST('2022-05-07', 'Date')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.697099 [ 5753 ] {be7f8959-4ff6-4c6e-bee8-6aee2e13770f} executeQuery: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate(CAST('2022-05-07', 'Date'), toIntervalMinute(5), 5). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:51586) (comment: 02834_add_sub_date_functions.sql) (in query: SELECT subDate('2022-05-07'::Date, INTERVAL 5 MINUTE, 5);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.697208 [ 5753 ] {be7f8959-4ff6-4c6e-bee8-6aee2e13770f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate(CAST('2022-05-07', 'Date'), toIntervalMinute(5), 5). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.722054 [ 5753 ] {d234fde5-ade2-4b11-8486-da9c6032e132} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of 2nd argument of function subDate. Should be an interval: In scope SELECT subDate(CAST('2022-05-07', 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:51586) (comment: 02834_add_sub_date_functions.sql) (in query: SELECT subDate('2022-05-07'::Date, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionOpDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000190ea066 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.722280 [ 5753 ] {d234fde5-ade2-4b11-8486-da9c6032e132} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of 2nd argument of function subDate. Should be an interval: In scope SELECT subDate(CAST('2022-05-07', 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionOpDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000190ea066 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.747770 [ 5753 ] {5bc2b9d4-5c2e-426a-8bb0-ae150f767fc4} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of 1st argument of function subDate. Should be a date, a date with time or a string: In scope SELECT subDate(1.2, toIntervalMinute(5)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:51586) (comment: 02834_add_sub_date_functions.sql) (in query: SELECT subDate(1.2, INTERVAL 5 MINUTE);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionOpDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000190ea2fd 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.747987 [ 5753 ] {5bc2b9d4-5c2e-426a-8bb0-ae150f767fc4} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of 1st argument of function subDate. Should be a date, a date with time or a string: In scope SELECT subDate(1.2, toIntervalMinute(5)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionOpDate::getReturnTypeImpl(std::vector> const&) const @ 0x00000000190ea2fd 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.820941 [ 5338 ] {05738838-ebca-46ce-99a4-b59768cf0a1a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50222) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompactEachRow settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:00.821426 [ 5338 ] {05738838-ebca-46ce-99a4-b59768cf0a1a} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 21. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:01.006514 [ 10241 ] {6863e9a2-d5e3-4213-8035-c2a67e192a19} executeQuery: Code: 48. DB::Exception: ALTER MODIFY SQL SECURITY is not supported by MergeTree engines family. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:51624) (comment: 02884_create_view_with_sql_security_option.sh) (in query: ALTER TABLE test_table MODIFY SQL SECURITY INVOKER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b43173 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:01.006848 [ 10241 ] {6863e9a2-d5e3-4213-8035-c2a67e192a19} TCPHandler: Code: 48. DB::Exception: ALTER MODIFY SQL SECURITY is not supported by MergeTree engines family. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b43173 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:01.239714 [ 10241 ] {0f7cb5f0-7eb6-418a-bb3b-2cf7fdb6b070} executeQuery: Code: 48. DB::Exception: ALTER MODIFY QUERY is not supported by MergeTree engines family. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:51662) (comment: 02834_alter_exception.sql) (in query: ALTER TABLE alter_02834 MODIFY QUERY SELECT a FROM alter_02834;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b43074 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:01.239942 [ 10241 ] {0f7cb5f0-7eb6-418a-bb3b-2cf7fdb6b070} TCPHandler: Code: 48. DB::Exception: ALTER MODIFY QUERY is not supported by MergeTree engines family. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b43074 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:01.759898 [ 10508 ] {46ad7b3d-17c4-455c-a6c7-56e2ab2d8107} executeQuery: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:51766) (comment: 02833_window_func_range_offset.sql) (in query: -- invalid start offset with RANGE SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN 0.0 PRECEDING AND UNBOUNDED FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x00000000316684ca 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:0: DB::WindowFrame::checkValid() const @ 0x0000000031667dc3 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:01.760117 [ 10508 ] {46ad7b3d-17c4-455c-a6c7-56e2ab2d8107} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x00000000316684ca 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:0: DB::WindowFrame::checkValid() const @ 0x0000000031667dc3 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:01.762118 [ 10508 ] {3d3464ef-e4cc-45b5-8bdb-ce6870e5e2d8} executeQuery: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:51766) (comment: 02833_window_func_range_offset.sql) (in query: SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN nan PRECEDING AND UNBOUNDED FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x00000000316684ca 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:0: DB::WindowFrame::checkValid() const @ 0x0000000031667dc3 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:01.762259 [ 10508 ] {3d3464ef-e4cc-45b5-8bdb-ce6870e5e2d8} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x00000000316684ca 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:0: DB::WindowFrame::checkValid() const @ 0x0000000031667dc3 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:01.785373 [ 10508 ] {8451efbe-d137-4d92-a4cf-08a20112c20f} executeQuery: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:51766) (comment: 02833_window_func_range_offset.sql) (in query: -- invalid end offset with RANGE SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN UNBOUNDED PRECEDING AND 0.0 FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x00000000316684ca 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:0: DB::WindowFrame::checkValid() const @ 0x0000000031667e8f 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:01.785589 [ 10508 ] {8451efbe-d137-4d92-a4cf-08a20112c20f} TCPHandler: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x00000000316684ca 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:0: DB::WindowFrame::checkValid() const @ 0x0000000031667e8f 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:01.787428 [ 10508 ] {2e7e4346-41c1-49b7-8719-b7e421a2f7dd} executeQuery: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:51766) (comment: 02833_window_func_range_offset.sql) (in query: SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN UNBOUNDED PRECEDING AND nan FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x00000000316684ca 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:0: DB::WindowFrame::checkValid() const @ 0x0000000031667e8f 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:01.787535 [ 10508 ] {2e7e4346-41c1-49b7-8719-b7e421a2f7dd} TCPHandler: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x00000000316684ca 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:0: DB::WindowFrame::checkValid() const @ 0x0000000031667e8f 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:01.910300 [ 10508 ] {db8e4d04-650b-4be8-bf05-544e0463153a} executeQuery: Code: 497. DB::Exception: user02884_1_test_6b349y97_6475: Not enough privileges. To execute this query, it's necessary to have the grant SET DEFINER ON user02884_2_test_6b349y97_17103. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:51818) (comment: 02884_create_view_with_sql_security_option.sh) (in query: CREATE VIEW test_6b349y97.test_view_g_2 DEFINER = user02884_2_test_6b349y97_17103 AS SELECT * FROM test_6b349y97.test_table; ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>>(DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed6b98b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>>(DB::AccessFlags, std::basic_string_view> const&) const @ 0x000000002ed6a3f5 6. ./build_docker/./src/Access/ContextAccess.cpp:725: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>) const @ 0x000000002ed2b02e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, std::basic_string_view> const&) const @ 0x000000002fc97309 8. ./build_docker/./src/Interpreters/Context.cpp:1402: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>) const @ 0x000000002fc4e479 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::processSQLSecurityOption(std::shared_ptr, DB::ASTSQLSecurity&, bool, bool) @ 0x00000000307c55b2 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307be0d5 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:01.910670 [ 10508 ] {db8e4d04-650b-4be8-bf05-544e0463153a} TCPHandler: Code: 497. DB::Exception: user02884_1_test_6b349y97_6475: Not enough privileges. To execute this query, it's necessary to have the grant SET DEFINER ON user02884_2_test_6b349y97_17103. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper>>(DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed6b98b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper>>(DB::AccessFlags, std::basic_string_view> const&) const @ 0x000000002ed6a3f5 6. ./build_docker/./src/Access/ContextAccess.cpp:725: DB::ContextAccess::checkAccess(DB::AccessFlags const&, std::basic_string_view>) const @ 0x000000002ed2b02e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, std::basic_string_view> const&) const @ 0x000000002fc97309 8. ./build_docker/./src/Interpreters/Context.cpp:1402: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>) const @ 0x000000002fc4e479 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::processSQLSecurityOption(std::shared_ptr, DB::ASTSQLSecurity&, bool, bool) @ 0x00000000307c55b2 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307be0d5 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:02.360034 [ 5338 ] {6b945011-b581-4120-b3af-c8b929e42759} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50234) (comment: 02835_drop_user_during_session.sh) (in query: SELECT COUNT(*) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:02.360084 [ 3522 ] {bb4dcfe1-40a5-4e04-85bd-f3107e221243} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50242) (comment: 02835_drop_user_during_session.sh) (in query: SELECT COUNT(*) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:02.373528 [ 10241 ] {5306577a-d3c5-4bac-bdce-43f76a46d896} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:51832) (comment: 02835_drop_user_during_session.sh) (in query: SELECT COUNT(*) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:02.373590 [ 5338 ] {6b945011-b581-4120-b3af-c8b929e42759} DynamicQueryHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:02.373675 [ 3522 ] {bb4dcfe1-40a5-4e04-85bd-f3107e221243} DynamicQueryHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:02.374008 [ 10241 ] {5306577a-d3c5-4bac-bdce-43f76a46d896} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:02.478828 [ 10241 ] {3f0e0bc0-5c3c-40fc-996b-f4e9c11251cd} executeQuery: Code: 497. DB::Exception: user02884_1_test_6b349y97_6475: Not enough privileges. To execute this query, it's necessary to have the grant ALLOW SQL SECURITY NONE ON *.*. (ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:51986) (comment: 02884_create_view_with_sql_security_option.sh) (in query: CREATE VIEW test_6b349y97.test_view_g_3 SQL SECURITY NONE AS SELECT * FROM test_6b349y97.test_table; ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper(DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed6818b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper(DB::AccessFlags) const @ 0x000000002ed66c11 6. ./build_docker/./src/Access/ContextAccess.cpp:724: DB::ContextAccess::checkAccess(DB::AccessFlags const&) const @ 0x000000002ed2afbd 7. ./build_docker/./src/Interpreters/Context.cpp:1398: void DB::Context::checkAccessImpl(DB::AccessFlags const&) const @ 0x000000002fc971fe 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::processSQLSecurityOption(std::shared_ptr, DB::ASTSQLSecurity&, bool, bool) @ 0x00000000307c5622 9. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307be0d5 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:02.479164 [ 10241 ] {3f0e0bc0-5c3c-40fc-996b-f4e9c11251cd} TCPHandler: Code: 497. DB::Exception: user02884_1_test_6b349y97_6475: Not enough privileges. To execute this query, it's necessary to have the grant ALLOW SQL SECURITY NONE ON *.*. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper(DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed6818b 5. ./build_docker/./src/Access/ContextAccess.cpp:586: bool DB::ContextAccess::checkAccessImplHelper(DB::AccessFlags) const @ 0x000000002ed66c11 6. ./build_docker/./src/Access/ContextAccess.cpp:724: DB::ContextAccess::checkAccess(DB::AccessFlags const&) const @ 0x000000002ed2afbd 7. ./build_docker/./src/Interpreters/Context.cpp:1398: void DB::Context::checkAccessImpl(DB::AccessFlags const&) const @ 0x000000002fc971fe 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::processSQLSecurityOption(std::shared_ptr, DB::ASTSQLSecurity&, bool, bool) @ 0x00000000307c5622 9. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307be0d5 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:02.776386 [ 5338 ] {8de5bf0e-d18d-4332-9682-7a57eadafb8d} executeQuery: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50256) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003380432e 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003357feb6 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:02.776994 [ 5338 ] {8de5bf0e-d18d-4332-9682-7a57eadafb8d} DynamicQueryHandler: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003380432e 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003357feb6 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:02.810711 [ 5338 ] {7de17300-56a8-4b10-8cc5-6821873df661} executeQuery: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing JSONEachRowRowOutputFormat. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50264) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x00000000337f7025 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003357feb6 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:02.811217 [ 5338 ] {7de17300-56a8-4b10-8cc5-6821873df661} DynamicQueryHandler: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing JSONEachRowRowOutputFormat. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x00000000337f7025 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003357feb6 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:02.838660 [ 5338 ] {45016ac0-50b8-4f5e-961c-dcb7aea60551} executeQuery: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactRowOutputFormat. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50270) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONCompact settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:23: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x00000000337ebe49 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003357feb6 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:02.839244 [ 5338 ] {45016ac0-50b8-4f5e-961c-dcb7aea60551} DynamicQueryHandler: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactRowOutputFormat. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:23: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x00000000337ebe49 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003357feb6 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:02.865593 [ 5338 ] {7b10fd07-911a-4a3b-b983-b9a3d2a788df} executeQuery: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactEachRowRowOutputFormat. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50274) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONCompactEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003357feb6 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 13. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 14. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 15. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:02.866099 [ 5338 ] {7b10fd07-911a-4a3b-b983-b9a3d2a788df} DynamicQueryHandler: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactEachRowRowOutputFormat. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003357feb6 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 13. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 14. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 15. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:02.895458 [ 5338 ] {489b47e1-79ce-4af8-af20-ba4910072a45} executeQuery: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing JSONObjectEachRowRowOutputFormat. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50288) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONObjectEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x00000000337f7025 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:33: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x00000000337fecd9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003357feb6 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 15. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 16. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 17. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:02.895980 [ 5338 ] {489b47e1-79ce-4af8-af20-ba4910072a45} DynamicQueryHandler: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing JSONObjectEachRowRowOutputFormat. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x00000000337f7025 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:33: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x00000000337fecd9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003357feb6 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 15. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 16. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 17. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:02.922987 [ 5338 ] {eaab46b3-fcbf-4da1-a199-f2707e128fdb} executeQuery: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing XMLRowOutputFormat. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50290) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format XML settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextXML(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5ea17c 7. ./build_docker/./src/Processors/Formats/Impl/XMLRowOutputFormat.cpp:78: DB::XMLRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000033b06d52 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003357feb6 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:02.923481 [ 5338 ] {eaab46b3-fcbf-4da1-a199-f2707e128fdb} DynamicQueryHandler: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing XMLRowOutputFormat. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextXML(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5ea17c 7. ./build_docker/./src/Processors/Formats/Impl/XMLRowOutputFormat.cpp:78: DB::XMLRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000033b06d52 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003357feb6 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:02.949924 [ 5338 ] {a9d89328-33f5-4e5e-8f8c-d6cbec85c2b8} executeQuery: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50298) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003380432e 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:235: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x00000000338b881a 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:02.950534 [ 5338 ] {a9d89328-33f5-4e5e-8f8c-d6cbec85c2b8} DynamicQueryHandler: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003380432e 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:235: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x00000000338b881a 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:03.162303 [ 3510 ] {bf9c393b-2dbe-44a4-aab7-1e943ff9bc49} executeQuery: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50314) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONCompact settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:23: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x00000000337ebe49 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:235: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x00000000338b881a 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:03.163015 [ 3510 ] {bf9c393b-2dbe-44a4-aab7-1e943ff9bc49} DynamicQueryHandler: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:23: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x00000000337ebe49 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:235: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x00000000338b881a 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:03.389176 [ 5753 ] {ab80bbcd-1347-4982-9f47-1c9562055318} executeQuery: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50322) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONObjectEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x00000000337f7025 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:33: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x00000000337fecd9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:235: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x00000000338b881a 12. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 13. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:03.389896 [ 5753 ] {ab80bbcd-1347-4982-9f47-1c9562055318} DynamicQueryHandler: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x00000000337f7025 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:33: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x00000000337fecd9 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:235: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x00000000338b881a 12. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 13. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:03.619821 [ 10508 ] {e05de5c0-1282-4917-995b-4fdd5ab66649} executeQuery: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50324) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x00000000337f7025 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:235: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x00000000338b881a 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:03.620533 [ 10508 ] {e05de5c0-1282-4917-995b-4fdd5ab66649} DynamicQueryHandler: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x00000000337f7025 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:235: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x00000000338b881a 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:03.832668 [ 3522 ] {d3a856f6-c299-4d85-b525-fa84b7fd5b5f} executeQuery: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50328) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONCompactEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 9. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:235: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x00000000338b881a 10. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 11. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:03.833320 [ 3522 ] {d3a856f6-c299-4d85-b525-fa84b7fd5b5f} DynamicQueryHandler: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 9. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:235: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x00000000338b881a 10. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 11. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:03.859763 [ 1658 ] {e58a768f-94aa-404e-92b0-6d6d7ee4f56c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50306) (comment: 02835_drop_user_during_session.sh) (in query: SELECT COUNT(*) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:03.859988 [ 5338 ] {09722429-f71d-47c3-aa23-7ab5b747074b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50304) (comment: 02835_drop_user_during_session.sh) (in query: SELECT COUNT(*) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:03.860061 [ 1658 ] {e58a768f-94aa-404e-92b0-6d6d7ee4f56c} DynamicQueryHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:03.860151 [ 3510 ] {4be9a449-62be-4ed7-9e86-1bddce43b29f} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:52126) (comment: 02835_drop_user_during_session.sh) (in query: SELECT COUNT(*) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:03.860279 [ 5338 ] {09722429-f71d-47c3-aa23-7ab5b747074b} DynamicQueryHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:03.860449 [ 3510 ] {4be9a449-62be-4ed7-9e86-1bddce43b29f} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:04.779993 [ 5753 ] {932770eb-0abd-4157-8ebf-503ad27eee75} OptimizeRegularExpression: Analyze RegularExpression failed, got error: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7fdd3c7fa000, frame address: 0x7fdd3cbf9fe0, stack size: 4194336, maximum stack size: 8388608. (TOO_DEEP_RECURSION) (version 24.3.12.76.altinitystable) 2025.03.05 21:09:04.814571 [ 5753 ] {932770eb-0abd-4157-8ebf-503ad27eee75} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: ((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((, error: missing ): ((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT match('', repeat('(', 100000)). (CANNOT_COMPILE_REGEXP) (version 24.3.12.76.altinitystable) (from [::1]:52552) (comment: 02831_regexp_analyze_recursion.sql) (in query: SELECT match('', repeat('(', 100000));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x00000000246a44f4 5. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x000000001ea2002c 6. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ea1aae1 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:04.815420 [ 5753 ] {932770eb-0abd-4157-8ebf-503ad27eee75} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: ((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((, error: missing ): ((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT match('', repeat('(', 100000)). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x00000000246a44f4 5. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x000000001ea2002c 6. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ea1aae1 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:05.219946 [ 5753 ] {0e64ce20-111c-4e0d-8d3c-084958809116} executeQuery: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50376) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003380432e 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003357feb6 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:05.220424 [ 5753 ] {0e64ce20-111c-4e0d-8d3c-084958809116} DynamicQueryHandler: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003380432e 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003357feb6 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:05.346213 [ 3522 ] {a2666eb2-5316-435f-8ed3-8bcc41b59771} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50338) (comment: 02835_drop_user_during_session.sh) (in query: SELECT COUNT(*) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:05.346214 [ 5338 ] {fac3e66b-7257-4375-b333-56f52dffe95e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50330) (comment: 02835_drop_user_during_session.sh) (in query: SELECT COUNT(*) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:05.346504 [ 5338 ] {fac3e66b-7257-4375-b333-56f52dffe95e} DynamicQueryHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:05.346553 [ 3522 ] {a2666eb2-5316-435f-8ed3-8bcc41b59771} DynamicQueryHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:05.346602 [ 10508 ] {bfd1227c-c6c8-41c9-98d6-0b01c0bef02c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:52528) (comment: 02835_drop_user_during_session.sh) (in query: SELECT COUNT(*) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:05.346900 [ 10508 ] {bfd1227c-c6c8-41c9-98d6-0b01c0bef02c} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:05.569860 [ 3510 ] {42255fa0-548e-44ef-9278-600d5794f9ca} executeQuery: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50388) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003380432e 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:235: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x00000000338b881a 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:05.570489 [ 3510 ] {42255fa0-548e-44ef-9278-600d5794f9ca} DynamicQueryHandler: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003380432e 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:235: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x00000000338b881a 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:05.622584 [ 10241 ] {26bc795f-cf15-4ca5-bbd4-926f69491935} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:52744) (comment: 02817_group_array_moving_zero_window_size.sql) (in query: SELECT groupArrayMovingAvg ( toInt64 ( 0 ) ) ( toDecimal32 ( 1 , 1 ) );), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002883fa01 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:05.622876 [ 10241 ] {26bc795f-cf15-4ca5-bbd4-926f69491935} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002883fa01 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:05.640310 [ 10241 ] {} DynamicQueryHandler: Code: 700. DB::Exception: User d347aafd-4457-a6d4-afc0-66a96af1a988 has overflown session count 1. (USER_SESSION_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x000000001886d833 4. ./build_docker/./src/Interpreters/SessionTracker.cpp:0: DB::SessionTracker::trackSession(StrongTypedef, DB::UUIDTag> const&, DB::SessionInfo const&, unsigned long) @ 0x00000000313505bd 5. ./build_docker/./src/Interpreters/Session.cpp:0: DB::Session::makeSessionContext(String const&, std::chrono::duration>, bool) @ 0x0000000031338a79 6. ./build_docker/./src/Server/HTTPHandler.cpp:568: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333cf02c 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:05.760230 [ 12483 ] {0f0e3c46-f14e-40d8-b0e6-60b6636b37f9} executeQuery: Code: 36. DB::Exception: Needle cannot be empty, because empty string isn't a token: In scope SELECT hasTokenCaseInsensitive('K(G', ''). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:52786) (comment: 02816_has_token_empty.sql) (in query: SELECT hasTokenCaseInsensitive('K(G', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::HasTokenImpl>, false>::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001cd9fcb9 5. DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd9d412 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:05.760431 [ 12483 ] {0f0e3c46-f14e-40d8-b0e6-60b6636b37f9} TCPHandler: Code: 36. DB::Exception: Needle cannot be empty, because empty string isn't a token: In scope SELECT hasTokenCaseInsensitive('K(G', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::HasTokenImpl>, false>::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001cd9fcb9 5. DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd9d412 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:05.762722 [ 12483 ] {8ee5951c-fde9-4438-80fa-2153d1ee5d92} executeQuery: Code: 36. DB::Exception: Needle cannot be empty, because empty string isn't a token: In scope SELECT hasTokenCaseInsensitive('Hello', ''). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:52786) (comment: 02816_has_token_empty.sql) (in query: SELECT hasTokenCaseInsensitive('Hello', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::HasTokenImpl>, false>::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001cd9fcb9 5. DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd9d412 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:05.762852 [ 12483 ] {8ee5951c-fde9-4438-80fa-2153d1ee5d92} TCPHandler: Code: 36. DB::Exception: Needle cannot be empty, because empty string isn't a token: In scope SELECT hasTokenCaseInsensitive('Hello', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::HasTokenImpl>, false>::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001cd9fcb9 5. DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd9d412 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:05.764209 [ 12483 ] {7a57ecf9-9217-4842-b088-ecf9c7f3c928} executeQuery: Code: 36. DB::Exception: Needle cannot be empty, because empty string isn't a token: In scope SELECT hasTokenCaseInsensitive('', ''). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:52786) (comment: 02816_has_token_empty.sql) (in query: SELECT hasTokenCaseInsensitive('', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::HasTokenImpl>, false>::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001cd9fcb9 5. DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd9d412 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:05.764358 [ 12483 ] {7a57ecf9-9217-4842-b088-ecf9c7f3c928} TCPHandler: Code: 36. DB::Exception: Needle cannot be empty, because empty string isn't a token: In scope SELECT hasTokenCaseInsensitive('', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::HasTokenImpl>, false>::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001cd9fcb9 5. DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd9d412 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:05.824775 [ 12483 ] {50bf74bf-f744-4128-ab82-8e287e816571} executeQuery: Code: 36. DB::Exception: Needle cannot be empty, because empty string isn't a token: In scope SELECT hasToken('Hello', ''). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:52786) (comment: 02816_has_token_empty.sql) (in query: SELECT hasToken('Hello', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::HasTokenImpl>, false>::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001cd96bf9 5. DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd94352 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:05.850678 [ 1658 ] {1d8d2f71-865d-43df-8417-872c49aa5c5d} executeQuery: Code: 36. DB::Exception: Point (1.8446744073709552e+19, 1.8446744073709552e+19) is invalid in function geoToS2. For valid point the latitude is between -90 and 90 degrees inclusiveand the longitude is between -180 and 180 degrees inclusive.: In scope SELECT geoToS2(toFloat64(toUInt64(-1)), toFloat64(toUInt64(-1))). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:52816) (comment: 02816_s2_invalid_point.sql) (in query: SELECT geoToS2(toFloat64(toUInt64(-1)), toFloat64(toUInt64(-1)));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, double const&, double const&, String&&) @ 0x000000001bafbf1b 4. DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bafb0ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:05.850765 [ 12483 ] {50bf74bf-f744-4128-ab82-8e287e816571} TCPHandler: Code: 36. DB::Exception: Needle cannot be empty, because empty string isn't a token: In scope SELECT hasToken('Hello', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::HasTokenImpl>, false>::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001cd96bf9 5. DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd94352 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:05.850947 [ 1658 ] {1d8d2f71-865d-43df-8417-872c49aa5c5d} TCPHandler: Code: 36. DB::Exception: Point (1.8446744073709552e+19, 1.8446744073709552e+19) is invalid in function geoToS2. For valid point the latitude is between -90 and 90 degrees inclusiveand the longitude is between -180 and 180 degrees inclusive.: In scope SELECT geoToS2(toFloat64(toUInt64(-1)), toFloat64(toUInt64(-1))). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, double const&, double const&, String&&) @ 0x000000001bafbf1b 4. DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bafb0ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:05.855236 [ 12483 ] {3cbc0d1e-ec52-466b-a8d6-8ccd2271b879} executeQuery: Code: 36. DB::Exception: Needle cannot be empty, because empty string isn't a token: In scope SELECT hasToken('', ''). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:52786) (comment: 02816_has_token_empty.sql) (in query: SELECT hasToken('', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::HasTokenImpl>, false>::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001cd96bf9 5. DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd94352 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:05.855365 [ 12483 ] {3cbc0d1e-ec52-466b-a8d6-8ccd2271b879} TCPHandler: Code: 36. DB::Exception: Needle cannot be empty, because empty string isn't a token: In scope SELECT hasToken('', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::HasTokenImpl>, false>::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001cd96bf9 5. DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd94352 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:06.463330 [ 3522 ] {2c5cc6ef-85d0-4481-ac48-29ccaf957eaf} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.0125730'): 0.0125730. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50450) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 5, sleep 0.0125730), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:06.463727 [ 3522 ] {2c5cc6ef-85d0-4481-ac48-29ccaf957eaf} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.0125730'): 0.0125730. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.484928 [ 3522 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.484967 [ 1658 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.497704 [ 3522 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.497778 [ 1658 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.507160 [ 3522 ] {fe170c67-6a51-4682-911b-147c869d17dc} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.011084'): 0.011084. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50488) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 5, sleep 0.011084), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:06.507371 [ 3522 ] {fe170c67-6a51-4682-911b-147c869d17dc} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.011084'): 0.011084. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.515077 [ 3522 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.515215 [ 3522 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.522818 [ 3522 ] {31e11ace-4860-44a3-85e4-f743a098fcc1} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.0122193'): 0.0122193. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50526) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 5, sleep 0.0122193), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:06.523037 [ 3522 ] {31e11ace-4860-44a3-85e4-f743a098fcc1} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.0122193'): 0.0122193. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.528405 [ 3522 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.528538 [ 3522 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.529796 [ 3522 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.530016 [ 3522 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.537866 [ 1658 ] {2fd1cff1-461a-4e17-af6a-6c7ec2caf24e} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.017714'): 0.017714. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50570) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 5, sleep 0.017714), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:06.538029 [ 1658 ] {2fd1cff1-461a-4e17-af6a-6c7ec2caf24e} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.017714'): 0.017714. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.545077 [ 1658 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.545224 [ 1658 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.552279 [ 3522 ] {29f19386-be23-42ff-826b-e00b025beea7} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.0110987'): 0.0110987. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50590) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 5, sleep 0.0110987), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:06.552434 [ 3522 ] {29f19386-be23-42ff-826b-e00b025beea7} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.0110987'): 0.0110987. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.556877 [ 1658 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.557045 [ 1658 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.558652 [ 1658 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.558822 [ 1658 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.564883 [ 12524 ] {c9b757c0-39ca-495f-a8d3-2d8945f28cb0} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.012922'): 0.012922. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50628) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 5, sleep 0.012922), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:06.565030 [ 12524 ] {c9b757c0-39ca-495f-a8d3-2d8945f28cb0} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.012922'): 0.012922. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.570728 [ 12524 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.570894 [ 12524 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.576840 [ 12524 ] {8cb4f516-35ad-4f06-9dd7-963cbebf5bfc} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.0128203'): 0.0128203. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50646) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 5, sleep 0.0128203), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:06.576988 [ 12524 ] {8cb4f516-35ad-4f06-9dd7-963cbebf5bfc} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.0128203'): 0.0128203. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.583449 [ 5338 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.583610 [ 5338 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.584134 [ 12524 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.584258 [ 12524 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.590185 [ 12524 ] {0a41a3d0-753b-41c7-870c-9cab47ec30ce} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.0125654'): 0.0125654. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50694) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 5, sleep 0.0125654), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:06.590365 [ 12524 ] {0a41a3d0-753b-41c7-870c-9cab47ec30ce} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.0125654'): 0.0125654. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.596904 [ 10241 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.597039 [ 10241 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.603818 [ 1658 ] {1f75a894-c2ea-40cb-9cea-4745e5e4d96c} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.0113434'): 0.0113434. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50710) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 5, sleep 0.0113434), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:06.604050 [ 1658 ] {1f75a894-c2ea-40cb-9cea-4745e5e4d96c} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.0113434'): 0.0113434. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.609749 [ 5338 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.609897 [ 5338 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.611720 [ 5338 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.611891 [ 5338 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.616237 [ 5338 ] {6060d78c-6b1c-4913-97ea-9c26a3079e06} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.0128513'): 0.0128513. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50744) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 5, sleep 0.0128513), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:06.616466 [ 5338 ] {6060d78c-6b1c-4913-97ea-9c26a3079e06} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.0128513'): 0.0128513. Expected one of: token, Dot, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.623135 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.623298 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_WITH_SESSION_ID_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.639859 [ 3510 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.640041 [ 3510 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.672788 [ 3510 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.673027 [ 3510 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.703429 [ 3510 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.703574 [ 3510 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.736897 [ 3510 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.737160 [ 3510 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.766366 [ 3510 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_HTTP_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.766517 [ 3510 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.827056 [ 1658 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_2: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.827077 [ 5338 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_1: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.842162 [ 5338 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_1: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.842273 [ 1658 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_2: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.872777 [ 2280 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_MYSQL_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:67: DB::MySQLProtocol::Authentication::Native41::authenticate(String const&, DB::Session&, std::optional, std::shared_ptr, bool, Poco::Net::SocketAddress const&) @ 0x000000002f9279de 12. ./build_docker/./src/Server/MySQLHandler.cpp:0: DB::MySQLHandler::authenticate(String const&, String const&, String const&) @ 0x00000000334352db 13. ./build_docker/./src/Server/MySQLHandler.cpp:241: DB::MySQLHandler::run() @ 0x000000003342f974 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:06.872976 [ 2280 ] {} MySQLHandler: Authentication for user 02833_MYSQL_USER_12024 failed. 2025.03.05 21:09:06.873098 [ 2280 ] {} MySQLHandler: DB::Exception: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. 2025.03.05 21:09:06.873341 [ 1658 ] {665d4970-3a63-4405-ae3e-035c6518dbad} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024): mysqlxx::ConnectionFailed 2025.03.05 21:09:06.873459 [ 1658 ] {665d4970-3a63-4405-ae3e-035c6518dbad} Application: Connection to system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024 failed: mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.03.05 21:09:06.873489 [ 1658 ] {665d4970-3a63-4405-ae3e-035c6518dbad} Application: Connection to mysql failed 1 times 2025.03.05 21:09:06.903424 [ 1658 ] {665d4970-3a63-4405-ae3e-035c6518dbad} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:53126) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', '02833_MYSQL_USER_12024', '[HIDDEN]', SETTINGS connection_max_tries = 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:06.903875 [ 1658 ] {665d4970-3a63-4405-ae3e-035c6518dbad} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:07.037213 [ 3510 ] {109a2e91-172f-4d7e-8bed-5595f19f8ef1} executeQuery: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50878) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003380432e 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003357feb6 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:07.037594 [ 3510 ] {109a2e91-172f-4d7e-8bed-5595f19f8ef1} DynamicQueryHandler: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003380432e 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003357feb6 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:07.217340 [ 5338 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_1: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:07.217418 [ 12524 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_2: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:07.217576 [ 5338 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_1: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:07.217688 [ 12524 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_2: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:07.249331 [ 12524 ] {cff53b19-5cf2-44d5-8c03-fa762fb67e76} executeQuery: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50886) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003380432e 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:235: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x00000000338b881a 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:07.249997 [ 12524 ] {cff53b19-5cf2-44d5-8c03-fa762fb67e76} DynamicQueryHandler: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003380432e 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:235: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x00000000338b881a 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:07.343557 [ 2280 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_MYSQL_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:67: DB::MySQLProtocol::Authentication::Native41::authenticate(String const&, DB::Session&, std::optional, std::shared_ptr, bool, Poco::Net::SocketAddress const&) @ 0x000000002f9279de 12. ./build_docker/./src/Server/MySQLHandler.cpp:0: DB::MySQLHandler::authenticate(String const&, String const&, String const&) @ 0x00000000334352db 13. ./build_docker/./src/Server/MySQLHandler.cpp:241: DB::MySQLHandler::run() @ 0x000000003342f974 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:07.343666 [ 2280 ] {} MySQLHandler: Authentication for user 02833_MYSQL_USER_12024 failed. 2025.03.05 21:09:07.343737 [ 2280 ] {} MySQLHandler: DB::Exception: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. 2025.03.05 21:09:07.343985 [ 5338 ] {cf06add0-e279-4a0d-8686-1943d80f42f2} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024): mysqlxx::ConnectionFailed 2025.03.05 21:09:07.344104 [ 5338 ] {cf06add0-e279-4a0d-8686-1943d80f42f2} Application: Connection to system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024 failed: mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.03.05 21:09:07.344129 [ 5338 ] {cf06add0-e279-4a0d-8686-1943d80f42f2} Application: Connection to mysql failed 1 times 2025.03.05 21:09:07.344629 [ 5338 ] {cf06add0-e279-4a0d-8686-1943d80f42f2} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:53210) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', '02833_MYSQL_USER_12024', '[HIDDEN]', SETTINGS connection_max_tries = 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:07.345107 [ 5338 ] {cf06add0-e279-4a0d-8686-1943d80f42f2} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:07.416982 [ 5338 ] {b3636a7c-f46e-4c9e-bfc8-f92c162613f8} executeQuery: Code: 80. DB::Exception: CREATE INDEX without TYPE is forbidden. SET allow_create_index_without_type=1 to ignore this statements. (INCORRECT_QUERY) (version 24.3.12.76.altinitystable) (from [::1]:53218) (comment: 02813_create_index_noop.sql) (in query: CREATE INDEX idx_tab1_0 on tab1 (col0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterCreateIndexQuery.cpp:0: DB::InterpreterCreateIndexQuery::execute() @ 0x00000000317ce1b1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:07.417226 [ 5338 ] {b3636a7c-f46e-4c9e-bfc8-f92c162613f8} TCPHandler: Code: 80. DB::Exception: CREATE INDEX without TYPE is forbidden. SET allow_create_index_without_type=1 to ignore this statements. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterCreateIndexQuery.cpp:0: DB::InterpreterCreateIndexQuery::execute() @ 0x00000000317ce1b1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:07.528166 [ 12524 ] {} TCPHandler: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by query. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x000000002eed2f62 4. ./build_docker/./src/Access/SettingsConstraints.cpp:378: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed1de5 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a85 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002eed10b2 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002fc65045 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002fc6581f 9. ./build_docker/./src/Server/TCPHandler.cpp:1884: DB::TCPHandler::receiveQuery() @ 0x00000000334b9efa 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003349bca4 11. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:07.616822 [ 10241 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_2: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:07.617080 [ 10241 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_2: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:07.618998 [ 12524 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_1: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:07.619500 [ 12524 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_1: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:07.727221 [ 3522 ] {d3bad47d-76ce-4c12-8e62-e4e8abf0e9e8} executeQuery: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by query. (READONLY) (version 24.3.12.76.altinitystable) (from [::1]:53328) (comment: 02832_alter_max_sessions_for_user.sh) (in query: SET max_sessions_for_user = 1 ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x000000002eed2f62 4. ./build_docker/./src/Access/SettingsConstraints.cpp:378: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed1de5 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a85 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002eed0ee2 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002fc65656 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x00000000310cdc3d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:07.727550 [ 3522 ] {d3bad47d-76ce-4c12-8e62-e4e8abf0e9e8} TCPHandler: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by query. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x000000002eed2f62 4. ./build_docker/./src/Access/SettingsConstraints.cpp:378: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed1de5 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a85 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002eed0ee2 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002fc65656 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x00000000310cdc3d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:07.797391 [ 2280 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_MYSQL_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:67: DB::MySQLProtocol::Authentication::Native41::authenticate(String const&, DB::Session&, std::optional, std::shared_ptr, bool, Poco::Net::SocketAddress const&) @ 0x000000002f9279de 12. ./build_docker/./src/Server/MySQLHandler.cpp:0: DB::MySQLHandler::authenticate(String const&, String const&, String const&) @ 0x00000000334352db 13. ./build_docker/./src/Server/MySQLHandler.cpp:241: DB::MySQLHandler::run() @ 0x000000003342f974 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:07.797493 [ 2280 ] {} MySQLHandler: Authentication for user 02833_MYSQL_USER_12024 failed. 2025.03.05 21:09:07.797541 [ 2280 ] {} MySQLHandler: DB::Exception: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. 2025.03.05 21:09:07.797697 [ 12524 ] {d8bad97d-4a32-490d-aa3a-5ce803290e5e} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024): mysqlxx::ConnectionFailed 2025.03.05 21:09:07.797788 [ 12524 ] {d8bad97d-4a32-490d-aa3a-5ce803290e5e} Application: Connection to system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024 failed: mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.03.05 21:09:07.797807 [ 12524 ] {d8bad97d-4a32-490d-aa3a-5ce803290e5e} Application: Connection to mysql failed 1 times 2025.03.05 21:09:07.798122 [ 12524 ] {d8bad97d-4a32-490d-aa3a-5ce803290e5e} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:53334) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', '02833_MYSQL_USER_12024', '[HIDDEN]', SETTINGS connection_max_tries = 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:07.798503 [ 12524 ] {d8bad97d-4a32-490d-aa3a-5ce803290e5e} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:07.920316 [ 12524 ] {} TCPHandler: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by query. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x000000002eed2f62 4. ./build_docker/./src/Access/SettingsConstraints.cpp:378: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed1de5 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a85 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002eed10b2 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002fc65045 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002fc6581f 9. ./build_docker/./src/Server/TCPHandler.cpp:1884: DB::TCPHandler::receiveQuery() @ 0x00000000334b9efa 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003349bca4 11. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:08.024118 [ 10241 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_1: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:08.024330 [ 10241 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_1: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:08.036761 [ 10241 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_2: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:08.037020 [ 10241 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_2: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:08.128057 [ 12524 ] {c2f39e90-f0f6-4c0e-810a-e7f698f4bc40} executeQuery: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by user. (READONLY) (version 24.3.12.76.altinitystable) (from [::1]:53418) (comment: 02832_alter_max_sessions_for_user.sh) (in query: CREATE USER 02832_alter_max_sessions_user_two_12111 SETTINGS max_sessions_for_user = 1 ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x000000002eed2f62 4. ./build_docker/./src/Access/SettingsConstraints.cpp:378: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed1de5 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a85 6. ./src/Common/SettingsChanges.h:9: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsProfileElements const&, DB::SettingSource) const @ 0x000000002eed0340 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsProfileElements const&, DB::SettingSource) @ 0x000000002fc64a05 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsProfileElements const&, DB::SettingSource) @ 0x000000002fc6551f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateUserQuery::execute() @ 0x0000000031887a4a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:08.128309 [ 12524 ] {c2f39e90-f0f6-4c0e-810a-e7f698f4bc40} TCPHandler: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by user. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x000000002eed2f62 4. ./build_docker/./src/Access/SettingsConstraints.cpp:378: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed1de5 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a85 6. ./src/Common/SettingsChanges.h:9: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsProfileElements const&, DB::SettingSource) const @ 0x000000002eed0340 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsProfileElements const&, DB::SettingSource) @ 0x000000002fc64a05 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsProfileElements const&, DB::SettingSource) @ 0x000000002fc6551f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateUserQuery::execute() @ 0x0000000031887a4a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:08.245493 [ 2280 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_MYSQL_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:67: DB::MySQLProtocol::Authentication::Native41::authenticate(String const&, DB::Session&, std::optional, std::shared_ptr, bool, Poco::Net::SocketAddress const&) @ 0x000000002f9279de 12. ./build_docker/./src/Server/MySQLHandler.cpp:0: DB::MySQLHandler::authenticate(String const&, String const&, String const&) @ 0x00000000334352db 13. ./build_docker/./src/Server/MySQLHandler.cpp:241: DB::MySQLHandler::run() @ 0x000000003342f974 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:08.245593 [ 2280 ] {} MySQLHandler: Authentication for user 02833_MYSQL_USER_12024 failed. 2025.03.05 21:09:08.245644 [ 2280 ] {} MySQLHandler: DB::Exception: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. 2025.03.05 21:09:08.245807 [ 12524 ] {35558755-404e-4891-a788-a873f72d255e} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024): mysqlxx::ConnectionFailed 2025.03.05 21:09:08.245887 [ 12524 ] {35558755-404e-4891-a788-a873f72d255e} Application: Connection to system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024 failed: mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.03.05 21:09:08.245932 [ 12524 ] {35558755-404e-4891-a788-a873f72d255e} Application: Connection to mysql failed 1 times 2025.03.05 21:09:08.246227 [ 12524 ] {35558755-404e-4891-a788-a873f72d255e} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:53450) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', '02833_MYSQL_USER_12024', '[HIDDEN]', SETTINGS connection_max_tries = 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:08.246461 [ 12524 ] {35558755-404e-4891-a788-a873f72d255e} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:08.324127 [ 12524 ] {ab8feb32-2e47-42ab-be3e-18f215f72b49} executeQuery: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by user. (READONLY) (version 24.3.12.76.altinitystable) (from [::1]:53458) (comment: 02832_alter_max_sessions_for_user.sh) (in query: ALTER USER 02832_alter_max_sessions_user_12111 SETTINGS max_sessions_for_user = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x000000002eed2f62 4. ./build_docker/./src/Access/SettingsConstraints.cpp:378: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed1de5 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a85 6. ./src/Common/SettingsChanges.h:9: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsProfileElements const&, DB::SettingSource) const @ 0x000000002eed0340 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsProfileElements const&, DB::SettingSource) @ 0x000000002fc64a05 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsProfileElements const&, DB::SettingSource) @ 0x000000002fc6551f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateUserQuery::execute() @ 0x0000000031887a4a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:08.324412 [ 12524 ] {ab8feb32-2e47-42ab-be3e-18f215f72b49} TCPHandler: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by user. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x000000002eed2f62 4. ./build_docker/./src/Access/SettingsConstraints.cpp:378: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed1de5 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a85 6. ./src/Common/SettingsChanges.h:9: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsProfileElements const&, DB::SettingSource) const @ 0x000000002eed0340 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsProfileElements const&, DB::SettingSource) @ 0x000000002fc64a05 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsProfileElements const&, DB::SettingSource) @ 0x000000002fc6551f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateUserQuery::execute() @ 0x0000000031887a4a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:08.403233 [ 5753 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_1: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:08.403646 [ 5753 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_1: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:08.407000 [ 12524 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_2: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:08.407283 [ 12524 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_2: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:08.568234 [ 12524 ] {b297d95b-f1a3-4456-bdf1-c2a7d61216b6} executeQuery: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by role. (READONLY) (version 24.3.12.76.altinitystable) (from [::1]:53500) (comment: 02832_alter_max_sessions_for_user.sh) (in query: CREATE ROLE 02832_alter_max_sessions_role_12111 SETTINGS max_sessions_for_user = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x000000002eed2f62 4. ./build_docker/./src/Access/SettingsConstraints.cpp:378: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed1de5 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a85 6. ./src/Common/SettingsChanges.h:9: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsProfileElements const&, DB::SettingSource) const @ 0x000000002eed0340 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsProfileElements const&, DB::SettingSource) @ 0x000000002fc64a05 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsProfileElements const&, DB::SettingSource) @ 0x000000002fc6551f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateRoleQuery::execute() @ 0x000000003187b290 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:08.568614 [ 12524 ] {b297d95b-f1a3-4456-bdf1-c2a7d61216b6} TCPHandler: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by role. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x000000002eed2f62 4. ./build_docker/./src/Access/SettingsConstraints.cpp:378: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed1de5 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a85 6. ./src/Common/SettingsChanges.h:9: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsProfileElements const&, DB::SettingSource) const @ 0x000000002eed0340 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsProfileElements const&, DB::SettingSource) @ 0x000000002fc64a05 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsProfileElements const&, DB::SettingSource) @ 0x000000002fc6551f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateRoleQuery::execute() @ 0x000000003187b290 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:08.675753 [ 2280 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_MYSQL_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:67: DB::MySQLProtocol::Authentication::Native41::authenticate(String const&, DB::Session&, std::optional, std::shared_ptr, bool, Poco::Net::SocketAddress const&) @ 0x000000002f9279de 12. ./build_docker/./src/Server/MySQLHandler.cpp:0: DB::MySQLHandler::authenticate(String const&, String const&, String const&) @ 0x00000000334352db 13. ./build_docker/./src/Server/MySQLHandler.cpp:241: DB::MySQLHandler::run() @ 0x000000003342f974 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:08.675930 [ 2280 ] {} MySQLHandler: Authentication for user 02833_MYSQL_USER_12024 failed. 2025.03.05 21:09:08.676011 [ 2280 ] {} MySQLHandler: DB::Exception: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. 2025.03.05 21:09:08.676170 [ 12524 ] {80e45624-f634-4366-b96a-7d98a04209de} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024): mysqlxx::ConnectionFailed 2025.03.05 21:09:08.676266 [ 12524 ] {80e45624-f634-4366-b96a-7d98a04209de} Application: Connection to system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024 failed: mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.03.05 21:09:08.676287 [ 12524 ] {80e45624-f634-4366-b96a-7d98a04209de} Application: Connection to mysql failed 1 times 2025.03.05 21:09:08.676680 [ 12524 ] {80e45624-f634-4366-b96a-7d98a04209de} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:53542) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', '02833_MYSQL_USER_12024', '[HIDDEN]', SETTINGS connection_max_tries = 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:08.676994 [ 12524 ] {80e45624-f634-4366-b96a-7d98a04209de} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:08.815546 [ 5753 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_2: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:08.815900 [ 5753 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_2: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:08.822017 [ 5753 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_1: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:08.822347 [ 5753 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_1: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:08.886735 [ 12525 ] {066bcd4d-a917-4837-8d96-1e7b45cc3ad6} executeQuery: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50894) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003380432e 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003357feb6 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:08.887827 [ 12525 ] {066bcd4d-a917-4837-8d96-1e7b45cc3ad6} DynamicQueryHandler: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003380432e 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:0: DB::IOutputFormat::work() @ 0x000000003357feb6 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:08.970067 [ 5753 ] {159249b3-0136-47ac-9244-a4e6f6c4fdea} executeQuery: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by role. (READONLY) (version 24.3.12.76.altinitystable) (from [::1]:57232) (comment: 02832_alter_max_sessions_for_user.sh) (in query: ALTER ROLE 02832_alter_max_sessions_role_12111 SETTINGS max_sessions_for_user = 1 ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x000000002eed2f62 4. ./build_docker/./src/Access/SettingsConstraints.cpp:378: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed1de5 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a85 6. ./src/Common/SettingsChanges.h:9: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsProfileElements const&, DB::SettingSource) const @ 0x000000002eed0340 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsProfileElements const&, DB::SettingSource) @ 0x000000002fc64a05 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsProfileElements const&, DB::SettingSource) @ 0x000000002fc6551f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateRoleQuery::execute() @ 0x000000003187b290 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:08.970328 [ 5753 ] {159249b3-0136-47ac-9244-a4e6f6c4fdea} TCPHandler: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by role. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x000000002eed2f62 4. ./build_docker/./src/Access/SettingsConstraints.cpp:378: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed1de5 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a85 6. ./src/Common/SettingsChanges.h:9: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsProfileElements const&, DB::SettingSource) const @ 0x000000002eed0340 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsProfileElements const&, DB::SettingSource) @ 0x000000002fc64a05 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsProfileElements const&, DB::SettingSource) @ 0x000000002fc6551f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateRoleQuery::execute() @ 0x000000003187b290 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:09.094976 [ 5753 ] {00ee888b-1475-4bc6-a7e7-dd16e7e89181} executeQuery: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:34922) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003380432e 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:235: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x00000000338b881a 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:09.095715 [ 5753 ] {00ee888b-1475-4bc6-a7e7-dd16e7e89181} DynamicQueryHandler: Code: 36. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. ./base/base/../base/StringRef.h:72: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e929c 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003380432e 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003358273d 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:52: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x00000000337e6209 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:235: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x00000000338b881a 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:09.140200 [ 2280 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_MYSQL_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:67: DB::MySQLProtocol::Authentication::Native41::authenticate(String const&, DB::Session&, std::optional, std::shared_ptr, bool, Poco::Net::SocketAddress const&) @ 0x000000002f9279de 12. ./build_docker/./src/Server/MySQLHandler.cpp:0: DB::MySQLHandler::authenticate(String const&, String const&, String const&) @ 0x00000000334352db 13. ./build_docker/./src/Server/MySQLHandler.cpp:241: DB::MySQLHandler::run() @ 0x000000003342f974 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:09.140309 [ 2280 ] {} MySQLHandler: Authentication for user 02833_MYSQL_USER_12024 failed. 2025.03.05 21:09:09.140403 [ 2280 ] {} MySQLHandler: DB::Exception: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. 2025.03.05 21:09:09.140548 [ 10241 ] {c7201e01-0342-4372-9dd6-10f33a571647} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024): mysqlxx::ConnectionFailed 2025.03.05 21:09:09.140656 [ 10241 ] {c7201e01-0342-4372-9dd6-10f33a571647} Application: Connection to system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024 failed: mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.03.05 21:09:09.140692 [ 10241 ] {c7201e01-0342-4372-9dd6-10f33a571647} Application: Connection to mysql failed 1 times 2025.03.05 21:09:09.141056 [ 10241 ] {c7201e01-0342-4372-9dd6-10f33a571647} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:57282) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', '02833_MYSQL_USER_12024', '[HIDDEN]', SETTINGS connection_max_tries = 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:09.141336 [ 10241 ] {c7201e01-0342-4372-9dd6-10f33a571647} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:09.200549 [ 10241 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_2: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:09.200843 [ 10241 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_2: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:09.209692 [ 10241 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_1: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:09.209940 [ 10241 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_1: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:09.589186 [ 2280 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_MYSQL_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:67: DB::MySQLProtocol::Authentication::Native41::authenticate(String const&, DB::Session&, std::optional, std::shared_ptr, bool, Poco::Net::SocketAddress const&) @ 0x000000002f9279de 12. ./build_docker/./src/Server/MySQLHandler.cpp:0: DB::MySQLHandler::authenticate(String const&, String const&, String const&) @ 0x00000000334352db 13. ./build_docker/./src/Server/MySQLHandler.cpp:241: DB::MySQLHandler::run() @ 0x000000003342f974 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:09.589364 [ 2280 ] {} MySQLHandler: Authentication for user 02833_MYSQL_USER_12024 failed. 2025.03.05 21:09:09.589443 [ 2280 ] {} MySQLHandler: DB::Exception: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. 2025.03.05 21:09:09.589603 [ 3522 ] {d963683b-6b36-41d9-8263-574314f8a6e0} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024): mysqlxx::ConnectionFailed 2025.03.05 21:09:09.589790 [ 3522 ] {d963683b-6b36-41d9-8263-574314f8a6e0} Application: Connection to system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024 failed: mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.03.05 21:09:09.589839 [ 3522 ] {d963683b-6b36-41d9-8263-574314f8a6e0} Application: Connection to mysql failed 1 times 2025.03.05 21:09:09.590354 [ 3522 ] {d963683b-6b36-41d9-8263-574314f8a6e0} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:57402) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', '02833_MYSQL_USER_12024', '[HIDDEN]', SETTINGS connection_max_tries = 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:09.590832 [ 3522 ] {d963683b-6b36-41d9-8263-574314f8a6e0} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:09.591719 [ 1658 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_2: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:09.592112 [ 1658 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_2: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:09.599207 [ 1658 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_1: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:09.599641 [ 1658 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_1: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:09.716612 [ 10241 ] {6b282f2e-3512-4e60-8ef8-a63760c3ef7b} executeQuery: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUInt64(toUUID('00000000-0000-0000-0000-000000000000')). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:57428) (comment: 02810_convert_uuid_to_uint128.sql) (in query: SELECT toUInt64(toUUID('00000000-0000-0000-0000-000000000000'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182eb77a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182e12ef 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:09.716930 [ 10241 ] {6b282f2e-3512-4e60-8ef8-a63760c3ef7b} TCPHandler: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUInt64(toUUID('00000000-0000-0000-0000-000000000000')). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182eb77a 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182e12ef 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:09.749555 [ 10241 ] {dfdbfcda-7b04-4126-b0a5-85aad2a1cf41} executeQuery: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toInt128(toUUID('00000000-0000-0000-0000-000000000000')). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:57428) (comment: 02810_convert_uuid_to_uint128.sql) (in query: SELECT toInt128(toUUID('00000000-0000-0000-0000-000000000000'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018393d6b 5. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001838956f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:09.749868 [ 10241 ] {dfdbfcda-7b04-4126-b0a5-85aad2a1cf41} TCPHandler: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toInt128(toUUID('00000000-0000-0000-0000-000000000000')). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018393d6b 5. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001838956f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:10.015031 [ 12483 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_2: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:10.015279 [ 12483 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_2: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:10.015575 [ 3510 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_1: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:10.015896 [ 3510 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_1: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:10.080432 [ 10241 ] {d9e2032f-8929-4e93-8914-e23fb57cbb0e} executeQuery: Code: 70. DB::Exception: Value in column Int256 cannot be safely converted into type Int32: while executing 'FUNCTION in(__table1.i :: 2, __set_15203497038766790673_12941400187266635952 :: 1) -> in(__table1.i, __set_15203497038766790673_12941400187266635952) Nullable(UInt8) : 0'. (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:57496) (comment: 02809_storage_set_analysis_bug.sql) (in query: SELECT count() = 1 FROM null_in__fuzz_6 PREWHERE 71 WHERE i IN (test_set);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x000000001836bd23 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018365f5b 6. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000185ca9cc 7. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000031693477 13. ./build_docker/./src/Interpreters/castColumn.cpp:51: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000031693a44 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000031355e90 15. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cec27e8 16. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 18. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForNulls(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83fc8b 19. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f6d1 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 21. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 22. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 23. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 24. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000033b59e3a 25. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:265: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000033b598fa 26. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 27. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 31. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 2025.03.05 21:09:10.080445 [ 2280 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_MYSQL_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:67: DB::MySQLProtocol::Authentication::Native41::authenticate(String const&, DB::Session&, std::optional, std::shared_ptr, bool, Poco::Net::SocketAddress const&) @ 0x000000002f9279de 12. ./build_docker/./src/Server/MySQLHandler.cpp:0: DB::MySQLHandler::authenticate(String const&, String const&, String const&) @ 0x00000000334352db 13. ./build_docker/./src/Server/MySQLHandler.cpp:241: DB::MySQLHandler::run() @ 0x000000003342f974 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:10.080702 [ 2280 ] {} MySQLHandler: Authentication for user 02833_MYSQL_USER_12024 failed. 2025.03.05 21:09:10.080811 [ 2280 ] {} MySQLHandler: DB::Exception: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. 2025.03.05 21:09:10.080947 [ 10241 ] {d9e2032f-8929-4e93-8914-e23fb57cbb0e} TCPHandler: Code: 70. DB::Exception: Value in column Int256 cannot be safely converted into type Int32: while executing 'FUNCTION in(__table1.i :: 2, __set_15203497038766790673_12941400187266635952 :: 1) -> in(__table1.i, __set_15203497038766790673_12941400187266635952) Nullable(UInt8) : 0'. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x000000001836bd23 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018365f5b 6. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000185ca9cc 7. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000031693477 13. ./build_docker/./src/Interpreters/castColumn.cpp:51: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000031693a44 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000031355e90 15. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cec27e8 16. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 18. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForNulls(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83fc8b 19. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f6d1 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 21. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 22. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 23. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 24. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000033b59e3a 25. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:265: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000033b598fa 26. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 27. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 31. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 2025.03.05 21:09:10.081054 [ 1658 ] {d1d60e26-45bf-483d-b307-deaad3d2773c} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024): mysqlxx::ConnectionFailed 2025.03.05 21:09:10.081170 [ 1658 ] {d1d60e26-45bf-483d-b307-deaad3d2773c} Application: Connection to system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024 failed: mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.03.05 21:09:10.081195 [ 1658 ] {d1d60e26-45bf-483d-b307-deaad3d2773c} Application: Connection to mysql failed 1 times 2025.03.05 21:09:10.081601 [ 1658 ] {d1d60e26-45bf-483d-b307-deaad3d2773c} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:57538) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', '02833_MYSQL_USER_12024', '[HIDDEN]', SETTINGS connection_max_tries = 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:10.082004 [ 1658 ] {d1d60e26-45bf-483d-b307-deaad3d2773c} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:10.406054 [ 3510 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_1: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:10.406360 [ 3510 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_1: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:10.418338 [ 3510 ] {} Access(user directories): from: ::1, user: 02833_TCP_USER_12024_2: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:10.418654 [ 3510 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_12024_2: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:10.584325 [ 2280 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_MYSQL_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:67: DB::MySQLProtocol::Authentication::Native41::authenticate(String const&, DB::Session&, std::optional, std::shared_ptr, bool, Poco::Net::SocketAddress const&) @ 0x000000002f9279de 12. ./build_docker/./src/Server/MySQLHandler.cpp:0: DB::MySQLHandler::authenticate(String const&, String const&, String const&) @ 0x00000000334352db 13. ./build_docker/./src/Server/MySQLHandler.cpp:241: DB::MySQLHandler::run() @ 0x000000003342f974 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:10.584434 [ 2280 ] {} MySQLHandler: Authentication for user 02833_MYSQL_USER_12024 failed. 2025.03.05 21:09:10.584500 [ 2280 ] {} MySQLHandler: DB::Exception: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. 2025.03.05 21:09:10.584807 [ 3510 ] {83e18460-5f09-4a7b-8d95-dd4a3e0fd3b9} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024): mysqlxx::ConnectionFailed 2025.03.05 21:09:10.584935 [ 3510 ] {83e18460-5f09-4a7b-8d95-dd4a3e0fd3b9} Application: Connection to system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024 failed: mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.03.05 21:09:10.584985 [ 3510 ] {83e18460-5f09-4a7b-8d95-dd4a3e0fd3b9} Application: Connection to mysql failed 1 times 2025.03.05 21:09:10.585552 [ 3510 ] {83e18460-5f09-4a7b-8d95-dd4a3e0fd3b9} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:57690) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', '02833_MYSQL_USER_12024', '[HIDDEN]', SETTINGS connection_max_tries = 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:10.586015 [ 3510 ] {83e18460-5f09-4a7b-8d95-dd4a3e0fd3b9} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:11.016870 [ 2280 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: 02833_MYSQL_USER_12024: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:67: DB::MySQLProtocol::Authentication::Native41::authenticate(String const&, DB::Session&, std::optional, std::shared_ptr, bool, Poco::Net::SocketAddress const&) @ 0x000000002f9279de 12. ./build_docker/./src/Server/MySQLHandler.cpp:0: DB::MySQLHandler::authenticate(String const&, String const&, String const&) @ 0x00000000334352db 13. ./build_docker/./src/Server/MySQLHandler.cpp:241: DB::MySQLHandler::run() @ 0x000000003342f974 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:11.017039 [ 2280 ] {} MySQLHandler: Authentication for user 02833_MYSQL_USER_12024 failed. 2025.03.05 21:09:11.017111 [ 2280 ] {} MySQLHandler: DB::Exception: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. 2025.03.05 21:09:11.017289 [ 3522 ] {f4fd83dd-244f-46e4-a3b7-80c09c7f917a} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024): mysqlxx::ConnectionFailed 2025.03.05 21:09:11.017401 [ 3522 ] {f4fd83dd-244f-46e4-a3b7-80c09c7f917a} Application: Connection to system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024 failed: mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.03.05 21:09:11.017429 [ 3522 ] {f4fd83dd-244f-46e4-a3b7-80c09c7f917a} Application: Connection to mysql failed 1 times 2025.03.05 21:09:11.017888 [ 3522 ] {f4fd83dd-244f-46e4-a3b7-80c09c7f917a} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:57754) (comment: 02833_concurrrent_sessions.sh) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', '02833_MYSQL_USER_12024', '[HIDDEN]', SETTINGS connection_max_tries = 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:11.018215 [ 3522 ] {f4fd83dd-244f-46e4-a3b7-80c09c7f917a} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_12024, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_12024: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x00000000366f21e3 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:88: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002f9446f8 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000032361e2b 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x00000000323616bf 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMySQL* std::construct_at[abi:v15000]&, DB::MySQLSettings, DB::StorageMySQL*>(DB::StorageMySQL*, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e342e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::MySQLSettings>(std::allocator, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2d84 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x000000002e4e2ad4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4e1fe7 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:11.384802 [ 10508 ] {c38bcc43-2435-48f8-ad96-38d764017e30} executeQuery: Code: 36. DB::Exception: Second argument to substringIndex must be a single character: In scope SELECT substringIndex('www.clickhouse.com', '..', 2). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:57776) (comment: 02798_substring_index.sql) (in query: select substringIndex('www.clickhouse.com', '..', 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000216c16c6 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:11.405463 [ 3510 ] {234b5eb0-3f42-4181-ad63-622dea8a0382} executeQuery: Code: 36. DB::Exception: Disk with name `s3_disk` already exist: While processing disk(name = 's3_disk', type = cache, max_size = '100Ki', path = `02808_custom_disk_with_user_defined_name_test_ho7j4hqv`, disk = s3_disk). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:57800) (comment: 02808_custom_disk_with_user_defined_name.sh) (in query: CREATE TABLE test (`a` Int32, `b` String) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = disk(name = 's3_disk', type = cache, max_size = '100Ki', path = `02808_custom_disk_with_user_defined_name_test_ho7j4hqv`, disk = s3_disk), index_granularity = 5192, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 188471824, compact_parts_max_granules_to_buffer = 92, compact_parts_merge_max_bytes_to_prefetch_part = 26692663, merge_max_block_size = 4347, old_parts_lifetime = 259., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 60, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 18853807, concurrent_part_removal_threshold = 96, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 44469, primary_key_compress_block_size = 29811), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Disks/getOrCreateDiskFromAST.cpp:57: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000032e449d4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:807: DB::getOrCreateDiskFromDiskAST(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000032e42ade 6. ./contrib/llvm-project/libcxx/include/string:843: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000032e15b50 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:613: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306bd13 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:11.405468 [ 10508 ] {c38bcc43-2435-48f8-ad96-38d764017e30} TCPHandler: Code: 36. DB::Exception: Second argument to substringIndex must be a single character: In scope SELECT substringIndex('www.clickhouse.com', '..', 2). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000216c16c6 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:11.405812 [ 3510 ] {234b5eb0-3f42-4181-ad63-622dea8a0382} TCPHandler: Code: 36. DB::Exception: Disk with name `s3_disk` already exist: While processing disk(name = 's3_disk', type = cache, max_size = '100Ki', path = `02808_custom_disk_with_user_defined_name_test_ho7j4hqv`, disk = s3_disk). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Disks/getOrCreateDiskFromAST.cpp:57: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000032e449d4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:807: DB::getOrCreateDiskFromDiskAST(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000032e42ade 6. ./contrib/llvm-project/libcxx/include/string:843: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000032e15b50 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:613: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306bd13 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:11.407720 [ 10508 ] {0b237b3d-41e9-4a44-80b6-1dbe15a31320} executeQuery: Code: 36. DB::Exception: Second argument to substringIndex must be a single character: In scope SELECT substringIndex('www.clickhouse.com', '', 2). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:57776) (comment: 02798_substring_index.sql) (in query: select substringIndex('www.clickhouse.com', '', 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000216c16c6 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:11.407883 [ 10508 ] {0b237b3d-41e9-4a44-80b6-1dbe15a31320} TCPHandler: Code: 36. DB::Exception: Second argument to substringIndex must be a single character: In scope SELECT substringIndex('www.clickhouse.com', '', 2). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000216c16c6 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:11.434515 [ 10508 ] {11fd0aba-a3a8-498a-9939-5d8dee1e91b0} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function substringIndex must be constant. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:57776) (comment: 02798_substring_index.sql) (in query: select substringIndex('www.clickhouse.com', materialize('.'), 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f0cc 5. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 10. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 12. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:11.434704 [ 10508 ] {11fd0aba-a3a8-498a-9939-5d8dee1e91b0} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function substringIndex must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f0cc 5. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 10. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 12. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:11.460181 [ 10508 ] {89371823-4924-4191-9335-2a53c9486f63} executeQuery: Code: 43. DB::Exception: Illegal type Int128 of third argument of function substringIndex, Integer expected: In scope SELECT substringIndex('www.clickhouse.com', '.', CAST(2, 'Int128')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:57776) (comment: 02798_substring_index.sql) (in query: select substringIndex('www.clickhouse.com', '.', cast(2 as Int128));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionSubstringIndex::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000216c23a5 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:11.460363 [ 10508 ] {89371823-4924-4191-9335-2a53c9486f63} TCPHandler: Code: 43. DB::Exception: Illegal type Int128 of third argument of function substringIndex, Integer expected: In scope SELECT substringIndex('www.clickhouse.com', '.', CAST(2, 'Int128')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionSubstringIndex::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000216c23a5 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:11.577550 [ 10508 ] {42fb94ca-44b5-41fd-982c-5dc48f19d83b} executeQuery: Code: 36. DB::Exception: Second argument to substringIndexUTF8 must be a single UTF-8 character: In scope SELECT substringIndexUTF8('富强,民主,文明', ',,', 2). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:57776) (comment: 02798_substring_index.sql) (in query: select substringIndexUTF8('富强,民主,文明', ',,', 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000216c4424 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:11.577769 [ 10508 ] {42fb94ca-44b5-41fd-982c-5dc48f19d83b} TCPHandler: Code: 36. DB::Exception: Second argument to substringIndexUTF8 must be a single UTF-8 character: In scope SELECT substringIndexUTF8('富强,民主,文明', ',,', 2). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000216c4424 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:11.580010 [ 10508 ] {153d33ee-15b2-4fd5-b87c-c063d16055a4} executeQuery: Code: 36. DB::Exception: Second argument to substringIndexUTF8 must be a single UTF-8 character: In scope SELECT substringIndexUTF8('富强,民主,文明', '', 2). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:57776) (comment: 02798_substring_index.sql) (in query: select substringIndexUTF8('富强,民主,文明', '', 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000216c4424 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:11.580125 [ 10508 ] {153d33ee-15b2-4fd5-b87c-c063d16055a4} TCPHandler: Code: 36. DB::Exception: Second argument to substringIndexUTF8 must be a single UTF-8 character: In scope SELECT substringIndexUTF8('富强,民主,文明', '', 2). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000216c4424 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:11.582188 [ 10508 ] {68c2e733-7a31-4f12-af8a-ee76d540adad} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function substringIndexUTF8 must be constant. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:57776) (comment: 02798_substring_index.sql) (in query: select substringIndexUTF8('富强,民主,文明', materialize(','), 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f0cc 5. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 10. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 12. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:11.582282 [ 10508 ] {68c2e733-7a31-4f12-af8a-ee76d540adad} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function substringIndexUTF8 must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f0cc 5. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 10. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 12. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:11.608422 [ 10508 ] {436ab078-0e56-4ed5-b9cf-fc09b15242e0} executeQuery: Code: 43. DB::Exception: Illegal type Int128 of third argument of function substringIndexUTF8, Integer expected: In scope SELECT substringIndexUTF8('富强,民主,文明', ',', CAST(2, 'Int128')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:57776) (comment: 02798_substring_index.sql) (in query: select substringIndexUTF8('富强,民主,文明', ',', cast(2 as Int128));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionSubstringIndex::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000216c5165 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:11.608672 [ 10508 ] {436ab078-0e56-4ed5-b9cf-fc09b15242e0} TCPHandler: Code: 43. DB::Exception: Illegal type Int128 of third argument of function substringIndexUTF8, Integer expected: In scope SELECT substringIndexUTF8('富强,民主,文明', ',', CAST(2, 'Int128')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionSubstringIndex::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000216c5165 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:12.482251 [ 10508 ] {031aa436-01ae-45ec-ab20-ecab3153ef96} executeQuery: Code: 59. DB::Exception: Illegal type Nullable(Int128) of column __table1.x for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.3.12.76.altinitystable) (from [::1]:57906) (comment: 02794_pushdown_invalid_get.sql) (in query: SELECT * FROM (SELECT toInt128(NULL) AS x UNION ALL SELECT materialize(toInt128(-2))) WHERE x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b58152 5. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 6. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 7. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:12.482462 [ 10508 ] {031aa436-01ae-45ec-ab20-ecab3153ef96} TCPHandler: Code: 59. DB::Exception: Illegal type Nullable(Int128) of column __table1.x for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b58152 5. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 6. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 7. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:13.408550 [ 10508 ] {ebd21621-fbea-4083-9f46-1e2138ef6680} executeQuery: Code: 48. DB::Exception: ColumnObject must be converted to ColumnTuple before use: While executing AggregatingTransform. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:57980) (comment: 02789_object_type_invalid_num_of_rows.sql) (in query: SELECT '0.02' GROUP BY GROUPING SETS (('6553.6'), (CAST('{"x" : 1}', 'Object(\'json\')'))) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./src/Columns/ColumnObject.h:259: DB::ColumnObject::throwMustBeConcrete() @ 0x0000000031b7f3ce 5. ./src/Columns/ColumnObject.h:242: DB::ColumnObject::serializeValueIntoArena(unsigned long, DB::Arena&, char const*&) const @ 0x0000000031b7bdc9 6. ./src/Interpreters/AggregationCommon.h:275: void DB::Aggregator::executeImplBatch, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodSerialized, char*, false, false>>(DB::AggregationMethodSerialized, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodSerialized, char*, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x00000000300891f0 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1041: void DB::Aggregator::executeImpl, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodSerialized, char*, false, false>>(DB::AggregationMethodSerialized, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodSerialized, char*, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000030088b9c 8. ./build_docker/./src/Interpreters/Aggregator.cpp:984: void DB::Aggregator::executeImpl, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>, false, false>>(DB::AggregationMethodSerialized, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>, false, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002fef64bf 9. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002fe5b149 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1626: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe6411b 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 16. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 17. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 18. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:13.408937 [ 10508 ] {ebd21621-fbea-4083-9f46-1e2138ef6680} TCPHandler: Code: 48. DB::Exception: ColumnObject must be converted to ColumnTuple before use: While executing AggregatingTransform. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./src/Columns/ColumnObject.h:259: DB::ColumnObject::throwMustBeConcrete() @ 0x0000000031b7f3ce 5. ./src/Columns/ColumnObject.h:242: DB::ColumnObject::serializeValueIntoArena(unsigned long, DB::Arena&, char const*&) const @ 0x0000000031b7bdc9 6. ./src/Interpreters/AggregationCommon.h:275: void DB::Aggregator::executeImplBatch, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodSerialized, char*, false, false>>(DB::AggregationMethodSerialized, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodSerialized, char*, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x00000000300891f0 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1041: void DB::Aggregator::executeImpl, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodSerialized, char*, false, false>>(DB::AggregationMethodSerialized, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodSerialized, char*, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000030088b9c 8. ./build_docker/./src/Interpreters/Aggregator.cpp:984: void DB::Aggregator::executeImpl, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>, false, false>>(DB::AggregationMethodSerialized, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>, false, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002fef64bf 9. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002fe5b149 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1626: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe6411b 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 16. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 17. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 18. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:14.639441 [ 3094 ] {adcae1ea-713b-4958-a1cf-02a5522ba5a8} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.000030017 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:48462) (comment: 02786_max_execution_time_leaf.sql) (in query: SELECT count() AS `count()` FROM view(SELECT * FROM numbers(100000000000)) AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002f42a262 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002f429bde 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:14.639481 [ 730 ] {1019146d-8fb2-41e5-b38c-9a3144dff725} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.000032822 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:55056) (comment: 02786_max_execution_time_leaf.sql) (in query: SELECT count() AS `count()` FROM view(SELECT * FROM numbers(100000000000)) AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002f42a262 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002f429bde 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:14.639663 [ 730 ] {1019146d-8fb2-41e5-b38c-9a3144dff725} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.000032822 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002f42a262 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002f429bde 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:14.639688 [ 3094 ] {adcae1ea-713b-4958-a1cf-02a5522ba5a8} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.000030017 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002f42a262 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002f429bde 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:14.641782 [ 12524 ] {5ddf1780-e619-429e-bfb5-adb3c1a42ad6} executeQuery: Code: 159. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Timeout exceeded: elapsed 1.000030017 seconds, maximum: 1. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002f42a262 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002f429bde 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 : While executing Remote. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:58040) (comment: 02786_max_execution_time_leaf.sql) (in query: SELECT count() FROM cluster('test_cluster_two_shards', view( SELECT * FROM numbers(100000000000) )) SETTINGS max_execution_time_leaf = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:09:14.642479 [ 12524 ] {5ddf1780-e619-429e-bfb5-adb3c1a42ad6} TCPHandler: Code: 159. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Timeout exceeded: elapsed 1.000030017 seconds, maximum: 1. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002f42a262 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002f429bde 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 : While executing Remote. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:09:15.837620 [ 3094 ] {e09fd037-7334-46e2-b1ac-5f86c4b88472} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'a' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.3.12.76.altinitystable) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference. You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.3.12.76.altinitystable) (from [::1]:58244) (comment: 02783_max_bytes_to_read_in_schema_inference.sql) (in query: desc format('JSONEachRow', '{"a" : null}, {"a" : 42}') settings input_format_max_bytes_to_read_for_schema_inference=10;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:480: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033518072 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4f121d 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:15.837937 [ 3094 ] {e09fd037-7334-46e2-b1ac-5f86c4b88472} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'a' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.3.12.76.altinitystable) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference. You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:480: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033518072 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4f121d 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:16.290119 [ 730 ] {584e3809-9e79-4349-b76b-422cc77ebf14} executeQuery: Code: 407. DB::Exception: Numeric overflow: while executing 'FUNCTION plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))) :: 3, multiply(__table2.number, 9223372036854775807_UInt64) :: 2) -> plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))), multiply(__table2.number, 9223372036854775807_UInt64)) DateTime : 0'. (DECIMAL_OVERFLOW) (version 24.3.12.76.altinitystable) (from [::1]:58332) (comment: 02772_jit_date_time_add.sql) (in query: SELECT DISTINCT result FROM (SELECT toStartOfFifteenMinutes(toDateTime(toStartOfFifteenMinutes(toDateTime(1000.0001220703125) + (number * 65536))) + (number * 9223372036854775807)) AS result FROM system.numbers LIMIT 1048576) ORDER BY result DESC NULLS FIRST FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short) const @ 0x000000001965e597 5. DB::DateTimeAddIntervalImpl::execute(DB::AddSecondsImpl, std::vector> const&, std::shared_ptr const&, unsigned short) @ 0x0000000019640e0a 6. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001963eae0 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x0000000020a3cb56 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a3a9f3 14. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 17. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:16.290375 [ 730 ] {584e3809-9e79-4349-b76b-422cc77ebf14} TCPHandler: Code: 407. DB::Exception: Numeric overflow: while executing 'FUNCTION plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))) :: 3, multiply(__table2.number, 9223372036854775807_UInt64) :: 2) -> plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))), multiply(__table2.number, 9223372036854775807_UInt64)) DateTime : 0'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short) const @ 0x000000001965e597 5. DB::DateTimeAddIntervalImpl::execute(DB::AddSecondsImpl, std::vector> const&, std::shared_ptr const&, unsigned short) @ 0x0000000019640e0a 6. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001963eae0 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x0000000020a3cb56 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a3a9f3 14. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 17. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:16.402361 [ 5753 ] {64808b08-5f72-4882-b80c-696ce7a1793d} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 2.00 million, current rows: 2.00 million. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:58298) (comment: 02781_data_skipping_index_merge_tree_min_for_seek.sql) (in query: SELECT * FROM data WHERE v1 >= now() - INTERVAL 180 DAY FORMAT Null SETTINGS max_threads=1, max_final_threads=1, force_data_skipping_indices='v1_index', merge_tree_min_rows_for_seek=1, max_rows_to_read=1999999;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:257: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f496ac 6. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:16.402562 [ 5753 ] {64808b08-5f72-4882-b80c-696ce7a1793d} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 2.00 million, current rows: 2.00 million. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:257: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f496ac 6. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:16.602642 [ 12483 ] {95ef1e7c-4c4f-477f-b479-082dfb2e3225} executeQuery: Code: 42. DB::Exception: The signature of table function s3 shall be the following: - url - url, format - url, format, structure - url, format, structure, compression_method - url, access_key_id, secret_access_key - url, access_key_id, secret_access_key, session_token - url, access_key_id, secret_access_key, format - url, access_key_id, secret_access_key, session_token, format - url, access_key_id, secret_access_key, format, structure - url, access_key_id, secret_access_key, session_token, format, structure - url, access_key_id, secret_access_key, format, structure, compression_method - url, access_key_id, secret_access_key, session_token, format, structure, compression_method All signatures supports optional headers (specified as `headers('name'='value', 'name2'='value2')`). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:58390) (comment: 02772_s3_crash.sql) (in query: SELECT * FROM s3(headers('random_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/TableFunctions/TableFunctionS3.cpp:0: DB::TableFunctionS3::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4a520e 5. ./build_docker/./src/TableFunctions/TableFunctionS3.cpp:0: DB::TableFunctionS3::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4a5c1d 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:16.602895 [ 12483 ] {95ef1e7c-4c4f-477f-b479-082dfb2e3225} TCPHandler: Code: 42. DB::Exception: The signature of table function s3 shall be the following: - url - url, format - url, format, structure - url, format, structure, compression_method - url, access_key_id, secret_access_key - url, access_key_id, secret_access_key, session_token - url, access_key_id, secret_access_key, format - url, access_key_id, secret_access_key, session_token, format - url, access_key_id, secret_access_key, format, structure - url, access_key_id, secret_access_key, session_token, format, structure - url, access_key_id, secret_access_key, format, structure, compression_method - url, access_key_id, secret_access_key, session_token, format, structure, compression_method All signatures supports optional headers (specified as `headers('name'='value', 'name2'='value2')`). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/TableFunctions/TableFunctionS3.cpp:0: DB::TableFunctionS3::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4a520e 5. ./build_docker/./src/TableFunctions/TableFunctionS3.cpp:0: DB::TableFunctionS3::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4a5c1d 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:16.627190 [ 12483 ] {f99a6103-3f8c-42fe-b5ad-f047de9fc6f2} executeQuery: Code: 42. DB::Exception: The signature of table function s3Cluster shall be the following: - cluster, url - cluster, url, format - cluster, url, format, structure - cluster, url, access_key_id, secret_access_key - cluster, url, format, structure, compression_method - cluster, url, access_key_id, secret_access_key, format - cluster, url, access_key_id, secret_access_key, format, structure - cluster, url, access_key_id, secret_access_key, format, structure, compression_method - cluster, url, access_key_id, secret_access_key, session_token, format, structure, compression_method All signatures supports optional headers (specified as `headers('name'='value', 'name2'='value2')`). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:58390) (comment: 02772_s3_crash.sql) (in query: SELECT * FROM s3Cluster('test_cluster_two_shards_localhost', headers('random_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/TableFunctions/TableFunctionS3.cpp:0: DB::TableFunctionS3::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4a520e 5. ./src/TableFunctions/ITableFunctionCluster.h:67: DB::ITableFunctionCluster::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4b76a4 6. ./build_docker/./src/TableFunctions/TableFunctionS3.cpp:0: DB::TableFunctionS3::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4a5c1d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionCluster::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4b70c4 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:16.627453 [ 12483 ] {f99a6103-3f8c-42fe-b5ad-f047de9fc6f2} TCPHandler: Code: 42. DB::Exception: The signature of table function s3Cluster shall be the following: - cluster, url - cluster, url, format - cluster, url, format, structure - cluster, url, access_key_id, secret_access_key - cluster, url, format, structure, compression_method - cluster, url, access_key_id, secret_access_key, format - cluster, url, access_key_id, secret_access_key, format, structure - cluster, url, access_key_id, secret_access_key, format, structure, compression_method - cluster, url, access_key_id, secret_access_key, session_token, format, structure, compression_method All signatures supports optional headers (specified as `headers('name'='value', 'name2'='value2')`). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/TableFunctions/TableFunctionS3.cpp:0: DB::TableFunctionS3::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4a520e 5. ./src/TableFunctions/ITableFunctionCluster.h:67: DB::ITableFunctionCluster::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4b76a4 6. ./build_docker/./src/TableFunctions/TableFunctionS3.cpp:0: DB::TableFunctionS3::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4a5c1d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionCluster::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4b70c4 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:19.598326 [ 14974 ] {b0d9e81c-ad1b-481c-b2a0-04548fb027f5} executeQuery: Code: 344. DB::Exception: FINAL modifier is not supported with parallel replicas. (SUPPORT_IS_DISABLED) (version 24.3.12.76.altinitystable) (from [::1]:50116) (comment: 02765_parallel_replicas_final_modifier.sql) (in query: SELECT * FROM parallel_replicas_final FINAL FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/Planner.cpp:1431: DB::Planner::buildPlanForQueryNode() @ 0x000000003100e792 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:19.598540 [ 14974 ] {b0d9e81c-ad1b-481c-b2a0-04548fb027f5} TCPHandler: Code: 344. DB::Exception: FINAL modifier is not supported with parallel replicas. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/Planner.cpp:1431: DB::Planner::buildPlanForQueryNode() @ 0x000000003100e792 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.397318 [ 14974 ] {8142b8a0-0cad-44b8-98a4-470cdc57deea} executeQuery: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:50236) (comment: 02752_forbidden_headers.sql) (in query: SELECT * FROM url('http://localhost:8123/', LineAsString, headers('exact_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb47d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000032666553 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageURL* std::construct_at[abi:v15000]&, String const&, std::vector> const&, String const&, DB::StorageURL*>(DB::StorageURL*, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e478eb9 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&, std::vector> const&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4788a4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4785f4 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e474635 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 12. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:09:20.397531 [ 14974 ] {8142b8a0-0cad-44b8-98a4-470cdc57deea} TCPHandler: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb47d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000032666553 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageURL* std::construct_at[abi:v15000]&, String const&, std::vector> const&, String const&, DB::StorageURL*>(DB::StorageURL*, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e478eb9 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&, std::vector> const&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4788a4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4785f4 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e474635 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 12. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:09:20.422370 [ 14974 ] {238e5b88-9b40-4d8c-b2de-6ca87680c255} executeQuery: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:50236) (comment: 02752_forbidden_headers.sql) (in query: SELECT * FROM url('http://localhost:8123/', LineAsString, headers('cAsE_INSENSITIVE_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:29: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb34f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000032666553 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageURL* std::construct_at[abi:v15000]&, String const&, std::vector> const&, String const&, DB::StorageURL*>(DB::StorageURL*, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e478eb9 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&, std::vector> const&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4788a4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4785f4 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e474635 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 12. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:09:20.422557 [ 14974 ] {238e5b88-9b40-4d8c-b2de-6ca87680c255} TCPHandler: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:29: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb34f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000032666553 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageURL* std::construct_at[abi:v15000]&, String const&, std::vector> const&, String const&, DB::StorageURL*>(DB::StorageURL*, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e478eb9 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&, std::vector> const&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4788a4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4785f4 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e474635 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 12. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:09:20.447008 [ 14974 ] {cd0b9a6a-314f-407b-99f2-affac8bf36f5} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:50236) (comment: 02752_forbidden_headers.sql) (in query: SELECT * FROM url('http://localhost:8123/', LineAsString, headers('bad_header_name: test\nexact_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb404 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000032666553 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageURL* std::construct_at[abi:v15000]&, String const&, std::vector> const&, String const&, DB::StorageURL*>(DB::StorageURL*, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e478eb9 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&, std::vector> const&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4788a4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4785f4 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e474635 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 12. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:09:20.447201 [ 14974 ] {cd0b9a6a-314f-407b-99f2-affac8bf36f5} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb404 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000032666553 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageURL* std::construct_at[abi:v15000]&, String const&, std::vector> const&, String const&, DB::StorageURL*>(DB::StorageURL*, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e478eb9 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&, std::vector> const&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4788a4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4785f4 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e474635 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 12. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:09:20.449401 [ 14974 ] {f07bc006-eca3-4321-8ac7-026dd4b2caf5} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:50236) (comment: 02752_forbidden_headers.sql) (in query: SELECT * FROM url('http://localhost:8123/', LineAsString, headers('bad_header_value' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb404 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000032666553 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageURL* std::construct_at[abi:v15000]&, String const&, std::vector> const&, String const&, DB::StorageURL*>(DB::StorageURL*, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e478eb9 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&, std::vector> const&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4788a4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4785f4 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e474635 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 12. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:09:20.449568 [ 14974 ] {f07bc006-eca3-4321-8ac7-026dd4b2caf5} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb404 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000032666553 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageURL* std::construct_at[abi:v15000]&, String const&, std::vector> const&, String const&, DB::StorageURL*>(DB::StorageURL*, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e478eb9 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&, std::vector> const&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4788a4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4785f4 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e474635 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 12. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:09:20.502983 [ 14974 ] {ced37144-cd08-4a60-92fa-582918e8bb7a} executeQuery: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:50236) (comment: 02752_forbidden_headers.sql) (in query: SELECT * FROM urlCluster('test_cluster_two_shards_localhost', 'http://localhost:8123/', LineAsString, headers('exact_header' = 'value'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb47d 5. ./build_docker/./src/Storages/StorageURLCluster.cpp:0: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x000000003267ef10 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&>(std::allocator, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x000000002e47cc0e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, void>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x000000002e47c94e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e47a998 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.503167 [ 14974 ] {ced37144-cd08-4a60-92fa-582918e8bb7a} TCPHandler: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb47d 5. ./build_docker/./src/Storages/StorageURLCluster.cpp:0: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x000000003267ef10 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&>(std::allocator, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x000000002e47cc0e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, void>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x000000002e47c94e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e47a998 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.527518 [ 14974 ] {c5bbcb64-d9ac-4df2-b3eb-7596f55b4a3d} executeQuery: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:50236) (comment: 02752_forbidden_headers.sql) (in query: SELECT * FROM urlCluster('test_cluster_two_shards_localhost', 'http://localhost:8123/', LineAsString, headers('cAsE_INSENSITIVE_header' = 'value'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:29: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb34f 5. ./build_docker/./src/Storages/StorageURLCluster.cpp:0: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x000000003267ef10 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&>(std::allocator, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x000000002e47cc0e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, void>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x000000002e47c94e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e47a998 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.527673 [ 14974 ] {c5bbcb64-d9ac-4df2-b3eb-7596f55b4a3d} TCPHandler: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:29: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb34f 5. ./build_docker/./src/Storages/StorageURLCluster.cpp:0: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x000000003267ef10 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&>(std::allocator, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x000000002e47cc0e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, void>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x000000002e47c94e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e47a998 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.552083 [ 14974 ] {ba1b106a-c49a-43a5-bc3d-f046c39f368d} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:50236) (comment: 02752_forbidden_headers.sql) (in query: SELECT * FROM urlCluster('test_cluster_two_shards_localhost', 'http://localhost:8123/', LineAsString, headers('bad_header_name: test\nexact_header' = 'value'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb404 5. ./build_docker/./src/Storages/StorageURLCluster.cpp:0: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x000000003267ef10 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&>(std::allocator, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x000000002e47cc0e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, void>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x000000002e47c94e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e47a998 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.552243 [ 14974 ] {ba1b106a-c49a-43a5-bc3d-f046c39f368d} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb404 5. ./build_docker/./src/Storages/StorageURLCluster.cpp:0: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x000000003267ef10 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&>(std::allocator, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x000000002e47cc0e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, void>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x000000002e47c94e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e47a998 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.554226 [ 14974 ] {d1adc275-d9e7-4190-9173-258b2e30139c} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:50236) (comment: 02752_forbidden_headers.sql) (in query: SELECT * FROM urlCluster('test_cluster_two_shards_localhost', 'http://localhost:8123/', LineAsString, headers('bad_header_value' = 'test\nexact_header: value'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb404 5. ./build_docker/./src/Storages/StorageURLCluster.cpp:0: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x000000003267ef10 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&>(std::allocator, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x000000002e47cc0e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, void>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x000000002e47c94e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e47a998 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.554333 [ 14974 ] {d1adc275-d9e7-4190-9173-258b2e30139c} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb404 5. ./build_docker/./src/Storages/StorageURLCluster.cpp:0: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x000000003267ef10 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&>(std::allocator, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x000000002e47cc0e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, void>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x000000002e47c94e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e47a998 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.590334 [ 14974 ] {0eb54257-f385-4145-a895-ad5da5b12673} executeQuery: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:50236) (comment: 02752_forbidden_headers.sql) (in query: SELECT * FROM s3('http://localhost:8123/123/4', LineAsString, headers('exact_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb47d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageS3::StorageS3(DB::StorageS3::Configuration const&, std::shared_ptr const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, bool, std::shared_ptr) @ 0x00000000325b7b76 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageS3* std::construct_at[abi:v15000]&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::StorageS3*>(DB::StorageS3*, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4ae284 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&>(std::allocator, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4adcbc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, void>(std::allocator const&, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4ada08 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionS3::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4a95f5 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.590544 [ 14974 ] {0eb54257-f385-4145-a895-ad5da5b12673} TCPHandler: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb47d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageS3::StorageS3(DB::StorageS3::Configuration const&, std::shared_ptr const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, bool, std::shared_ptr) @ 0x00000000325b7b76 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageS3* std::construct_at[abi:v15000]&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::StorageS3*>(DB::StorageS3*, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4ae284 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&>(std::allocator, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4adcbc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, void>(std::allocator const&, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4ada08 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionS3::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4a95f5 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.618046 [ 14974 ] {221570e8-aa08-46dc-a499-270773909a9e} executeQuery: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:50236) (comment: 02752_forbidden_headers.sql) (in query: SELECT * FROM s3('http://localhost:8123/123/4', LineAsString, headers('cAsE_INSENSITIVE_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:29: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb34f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageS3::StorageS3(DB::StorageS3::Configuration const&, std::shared_ptr const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, bool, std::shared_ptr) @ 0x00000000325b7b76 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageS3* std::construct_at[abi:v15000]&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::StorageS3*>(DB::StorageS3*, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4ae284 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&>(std::allocator, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4adcbc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, void>(std::allocator const&, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4ada08 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionS3::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4a95f5 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.618269 [ 14974 ] {221570e8-aa08-46dc-a499-270773909a9e} TCPHandler: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:29: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb34f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageS3::StorageS3(DB::StorageS3::Configuration const&, std::shared_ptr const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, bool, std::shared_ptr) @ 0x00000000325b7b76 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageS3* std::construct_at[abi:v15000]&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::StorageS3*>(DB::StorageS3*, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4ae284 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&>(std::allocator, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4adcbc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, void>(std::allocator const&, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4ada08 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionS3::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4a95f5 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.656636 [ 14974 ] {71a8192d-2835-49de-8728-042d471b8ab5} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:50236) (comment: 02752_forbidden_headers.sql) (in query: SELECT * FROM s3('http://localhost:8123/123/4', LineAsString, headers('bad_header_name: test\nexact_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb404 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageS3::StorageS3(DB::StorageS3::Configuration const&, std::shared_ptr const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, bool, std::shared_ptr) @ 0x00000000325b7b76 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageS3* std::construct_at[abi:v15000]&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::StorageS3*>(DB::StorageS3*, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4ae284 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&>(std::allocator, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4adcbc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, void>(std::allocator const&, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4ada08 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionS3::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4a95f5 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.656915 [ 14974 ] {71a8192d-2835-49de-8728-042d471b8ab5} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb404 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageS3::StorageS3(DB::StorageS3::Configuration const&, std::shared_ptr const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, bool, std::shared_ptr) @ 0x00000000325b7b76 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageS3* std::construct_at[abi:v15000]&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::StorageS3*>(DB::StorageS3*, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4ae284 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&>(std::allocator, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4adcbc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, void>(std::allocator const&, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4ada08 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionS3::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4a95f5 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.662565 [ 14974 ] {07961197-d45f-4437-8f30-0b0b7b339bae} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:50236) (comment: 02752_forbidden_headers.sql) (in query: SELECT * FROM s3('http://localhost:8123/123/4', LineAsString, headers('bad_header_value' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb404 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageS3::StorageS3(DB::StorageS3::Configuration const&, std::shared_ptr const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, bool, std::shared_ptr) @ 0x00000000325b7b76 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageS3* std::construct_at[abi:v15000]&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::StorageS3*>(DB::StorageS3*, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4ae284 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&>(std::allocator, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4adcbc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, void>(std::allocator const&, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4ada08 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionS3::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4a95f5 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.662740 [ 14974 ] {07961197-d45f-4437-8f30-0b0b7b339bae} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb404 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageS3::StorageS3(DB::StorageS3::Configuration const&, std::shared_ptr const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, bool, std::shared_ptr) @ 0x00000000325b7b76 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageS3* std::construct_at[abi:v15000]&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::StorageS3*>(DB::StorageS3*, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4ae284 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&>(std::allocator, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4adcbc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, void>(std::allocator const&, DB::StorageS3::Configuration&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&) @ 0x000000002e4ada08 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionS3::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4a95f5 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.687560 [ 14974 ] {1934ac47-d045-45bd-a7ac-505cc5551018} executeQuery: Code: 499. DB::Exception: Failed to get object info: No response body.. HTTP response code: 404: While executing S3. (S3_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:50236) (comment: 02752_forbidden_headers.sql) (in query: SELECT * FROM s3('http://localhost:8123/123/4', LineAsString, headers('random_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(Aws::S3::S3Errors, fmt::v8::basic_format_string::type, fmt::v8::type_identity::type>, String const&, unsigned long&&) @ 0x000000002e9e5d18 4. ./build_docker/./src/IO/S3/getObjectInfo.cpp:88: DB::S3::getObjectInfo(DB::S3::Client const&, String const&, String const&, String const&, DB::S3Settings::RequestSettings const&, bool, bool, bool) @ 0x000000002e9e52f9 5. ./build_docker/./src/Storages/StorageS3.cpp:478: DB::StorageS3Source::KeysIterator::Impl::next(unsigned long) @ 0x00000000325cfe57 6. ./build_docker/./src/Storages/StorageS3.cpp:621: DB::StorageS3Source::createReader(unsigned long) @ 0x00000000325b0465 7. ./build_docker/./src/Storages/StorageS3.cpp:610: DB::StorageS3Source::lazyInitialize(unsigned long) @ 0x00000000325aff39 8. ./build_docker/./src/Storages/StorageS3.cpp:0: DB::StorageS3Source::generate() @ 0x00000000325b57f4 9. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 15. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.688977 [ 14974 ] {1934ac47-d045-45bd-a7ac-505cc5551018} TCPHandler: Code: 499. DB::Exception: Failed to get object info: No response body.. HTTP response code: 404: While executing S3. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(Aws::S3::S3Errors, fmt::v8::basic_format_string::type, fmt::v8::type_identity::type>, String const&, unsigned long&&) @ 0x000000002e9e5d18 4. ./build_docker/./src/IO/S3/getObjectInfo.cpp:88: DB::S3::getObjectInfo(DB::S3::Client const&, String const&, String const&, String const&, DB::S3Settings::RequestSettings const&, bool, bool, bool) @ 0x000000002e9e52f9 5. ./build_docker/./src/Storages/StorageS3.cpp:478: DB::StorageS3Source::KeysIterator::Impl::next(unsigned long) @ 0x00000000325cfe57 6. ./build_docker/./src/Storages/StorageS3.cpp:621: DB::StorageS3Source::createReader(unsigned long) @ 0x00000000325b0465 7. ./build_docker/./src/Storages/StorageS3.cpp:610: DB::StorageS3Source::lazyInitialize(unsigned long) @ 0x00000000325aff39 8. ./build_docker/./src/Storages/StorageS3.cpp:0: DB::StorageS3Source::generate() @ 0x00000000325b57f4 9. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 15. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.720704 [ 14974 ] {28130d1c-01bc-4097-944a-68d5b66e39c6} executeQuery: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:50236) (comment: 02752_forbidden_headers.sql) (in query: SELECT * FROM s3Cluster('test_cluster_two_shards_localhost', 'http://localhost:8123/123/4', LineAsString, headers('exact_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb47d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageS3Cluster::StorageS3Cluster(String const&, DB::StorageS3::Configuration const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, std::shared_ptr const&) @ 0x00000000325ef943 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&>(std::allocator, String const&, DB::StorageS3::Configuration&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x000000002e4b850a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageS3::Configuration&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, std::shared_ptr&, void>(std::allocator const&, String const&, DB::StorageS3::Configuration&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x000000002e4b824a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionS3Cluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4b6204 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 10. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.721085 [ 14974 ] {28130d1c-01bc-4097-944a-68d5b66e39c6} TCPHandler: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb47d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageS3Cluster::StorageS3Cluster(String const&, DB::StorageS3::Configuration const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, std::shared_ptr const&) @ 0x00000000325ef943 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&>(std::allocator, String const&, DB::StorageS3::Configuration&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x000000002e4b850a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageS3::Configuration&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, std::shared_ptr&, void>(std::allocator const&, String const&, DB::StorageS3::Configuration&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x000000002e4b824a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionS3Cluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4b6204 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 10. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.754823 [ 14974 ] {85c179ad-fdf7-4997-ba9c-aa82f74c5b20} executeQuery: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:50236) (comment: 02752_forbidden_headers.sql) (in query: SELECT * FROM s3Cluster('test_cluster_two_shards_localhost', 'http://localhost:8123/123/4', LineAsString, headers('cAsE_INSENSITIVE_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:29: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb34f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageS3Cluster::StorageS3Cluster(String const&, DB::StorageS3::Configuration const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, std::shared_ptr const&) @ 0x00000000325ef943 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&>(std::allocator, String const&, DB::StorageS3::Configuration&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x000000002e4b850a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageS3::Configuration&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, std::shared_ptr&, void>(std::allocator const&, String const&, DB::StorageS3::Configuration&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x000000002e4b824a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionS3Cluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4b6204 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 10. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.755135 [ 14974 ] {85c179ad-fdf7-4997-ba9c-aa82f74c5b20} TCPHandler: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:29: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb34f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageS3Cluster::StorageS3Cluster(String const&, DB::StorageS3::Configuration const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, std::shared_ptr const&) @ 0x00000000325ef943 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&>(std::allocator, String const&, DB::StorageS3::Configuration&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x000000002e4b850a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageS3::Configuration&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, std::shared_ptr&, void>(std::allocator const&, String const&, DB::StorageS3::Configuration&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x000000002e4b824a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionS3Cluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4b6204 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 10. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.788593 [ 14974 ] {5e61229a-2791-40af-8743-cd2eccd96578} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:50236) (comment: 02752_forbidden_headers.sql) (in query: SELECT * FROM s3Cluster('test_cluster_two_shards_localhost', 'http://localhost:8123/123/4', LineAsString, headers('bad_header_name: test\nexact_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb404 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageS3Cluster::StorageS3Cluster(String const&, DB::StorageS3::Configuration const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, std::shared_ptr const&) @ 0x00000000325ef943 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&>(std::allocator, String const&, DB::StorageS3::Configuration&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x000000002e4b850a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageS3::Configuration&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, std::shared_ptr&, void>(std::allocator const&, String const&, DB::StorageS3::Configuration&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x000000002e4b824a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionS3Cluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4b6204 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 10. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.788857 [ 14974 ] {5e61229a-2791-40af-8743-cd2eccd96578} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb404 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageS3Cluster::StorageS3Cluster(String const&, DB::StorageS3::Configuration const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, std::shared_ptr const&) @ 0x00000000325ef943 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&>(std::allocator, String const&, DB::StorageS3::Configuration&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x000000002e4b850a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageS3::Configuration&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, std::shared_ptr&, void>(std::allocator const&, String const&, DB::StorageS3::Configuration&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x000000002e4b824a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionS3Cluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4b6204 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 10. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.791216 [ 14974 ] {23ec3cf9-f25b-4d36-8b3e-f2d2e87dad62} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:50236) (comment: 02752_forbidden_headers.sql) (in query: SELECT * FROM s3Cluster('test_cluster_two_shards_localhost', 'http://localhost:8123/123/4', LineAsString, headers('bad_header_value' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb404 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageS3Cluster::StorageS3Cluster(String const&, DB::StorageS3::Configuration const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, std::shared_ptr const&) @ 0x00000000325ef943 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&>(std::allocator, String const&, DB::StorageS3::Configuration&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x000000002e4b850a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageS3::Configuration&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, std::shared_ptr&, void>(std::allocator const&, String const&, DB::StorageS3::Configuration&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x000000002e4b824a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionS3Cluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4b6204 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 10. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.791321 [ 14974 ] {23ec3cf9-f25b-4d36-8b3e-f2d2e87dad62} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:0: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000290bb404 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageS3Cluster::StorageS3Cluster(String const&, DB::StorageS3::Configuration const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, std::shared_ptr const&) @ 0x00000000325ef943 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&>(std::allocator, String const&, DB::StorageS3::Configuration&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x000000002e4b850a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageS3::Configuration&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, std::shared_ptr&, void>(std::allocator const&, String const&, DB::StorageS3::Configuration&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x000000002e4b824a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionS3Cluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4b6204 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 10. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.849210 [ 1658 ] {} virtual DB::WriteBufferFromPocoSocket::~WriteBufferFromPocoSocket(): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:54336). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. DB::WriteBuffer::finalize() @ 0x0000000018076036 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::WriteBufferFromPocoSocket::~WriteBufferFromPocoSocket() @ 0x0000000024883af4 8. std::__shared_count::__release_shared[abi:v15000]() @ 0x0000000018060160 9. std::__shared_weak_count::__release_shared[abi:v15000]() @ 0x0000000018060001 10. ./src/Server/HTTP/HTTPServerResponse.h:189: DB::HTTPServerResponse::~HTTPServerResponse() @ 0x00000000334d6dc6 11. ./contrib/llvm-project/libcxx/include/atomic:958: DB::HTTPServerConnection::run() @ 0x00000000334d57d4 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:20.862729 [ 14974 ] {07cb294e-c500-428c-9b17-9b30352c7207} executeQuery: Code: 499. DB::Exception: Failed to get object info: No response body.. HTTP response code: 404: While executing Remote. (S3_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:50236) (comment: 02752_forbidden_headers.sql) (in query: SELECT * FROM s3Cluster('test_cluster_two_shards_localhost', 'http://localhost:8123/123/4', LineAsString, headers('random_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(Aws::S3::S3Errors, fmt::v8::basic_format_string::type, fmt::v8::type_identity::type>, String const&, unsigned long&&) @ 0x000000002e9e5d18 4. ./build_docker/./src/IO/S3/getObjectInfo.cpp:88: DB::S3::getObjectInfo(DB::S3::Client const&, String const&, String const&, String const&, DB::S3Settings::RequestSettings const&, bool, bool, bool) @ 0x000000002e9e52f9 5. ./build_docker/./src/Storages/StorageS3.cpp:273: DB::StorageS3Source::DisclosedGlobIterator::Impl::nextAssumeLocked() @ 0x00000000325d3574 6. ./build_docker/./src/Storages/StorageS3.cpp:0: DB::StorageS3Source::DisclosedGlobIterator::next(unsigned long) @ 0x00000000325ae0ac 7. ./build_docker/./src/Storages/StorageS3Cluster.cpp:98: String std::__function::__policy_invoker::__call_impl const&) const::$_0, String ()>>(std::__function::__policy_storage const*) @ 0x00000000325f1474 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::RemoteQueryExecutor::processReadTaskRequest() @ 0x000000002f434b2c 9. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:565: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x000000002f431f1f 10. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:502: DB::RemoteQueryExecutor::readAsync() @ 0x000000002f433d43 11. ./src/QueryPipeline/RemoteQueryExecutor.h:161: DB::RemoteSource::tryGenerate() @ 0x0000000033cf1215 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 18. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.877837 [ 1658 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:20.878294 [ 14974 ] {07cb294e-c500-428c-9b17-9b30352c7207} TCPHandler: Code: 499. DB::Exception: Failed to get object info: No response body.. HTTP response code: 404: While executing Remote. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(Aws::S3::S3Errors, fmt::v8::basic_format_string::type, fmt::v8::type_identity::type>, String const&, unsigned long&&) @ 0x000000002e9e5d18 4. ./build_docker/./src/IO/S3/getObjectInfo.cpp:88: DB::S3::getObjectInfo(DB::S3::Client const&, String const&, String const&, String const&, DB::S3Settings::RequestSettings const&, bool, bool, bool) @ 0x000000002e9e52f9 5. ./build_docker/./src/Storages/StorageS3.cpp:273: DB::StorageS3Source::DisclosedGlobIterator::Impl::nextAssumeLocked() @ 0x00000000325d3574 6. ./build_docker/./src/Storages/StorageS3.cpp:0: DB::StorageS3Source::DisclosedGlobIterator::next(unsigned long) @ 0x00000000325ae0ac 7. ./build_docker/./src/Storages/StorageS3Cluster.cpp:98: String std::__function::__policy_invoker::__call_impl const&) const::$_0, String ()>>(std::__function::__policy_storage const*) @ 0x00000000325f1474 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::RemoteQueryExecutor::processReadTaskRequest() @ 0x000000002f434b2c 9. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:565: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x000000002f431f1f 10. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:502: DB::RemoteQueryExecutor::readAsync() @ 0x000000002f433d43 11. ./src/QueryPipeline/RemoteQueryExecutor.h:161: DB::RemoteSource::tryGenerate() @ 0x0000000033cf1215 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 18. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:20.892138 [ 5753 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::1]:50262). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:21.119826 [ 14973 ] {a372cb74-d0fb-4815-974d-ac1b65d9fa9c} executeQuery: Code: 36. DB::Exception: Invalid time zone: Ðбырвалг. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:50354) (comment: 02737_session_timezone.sql) (in query: SET session_timezone = 'Ðбырвалг';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Core/SettingsFields.cpp:553: DB::SettingFieldTimezone::validateTimezone(String const&) @ 0x000000002f36efde 5. ./contrib/llvm-project/libcxx/include/string:2497: DB::SettingFieldTimezone::SettingFieldTimezone(DB::Field const&) @ 0x000000002f2f944a 6. ./build_docker/./src/Core/Settings.cpp:21: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda1475'(DB::Field const&)::__invoke(DB::Field const&) @ 0x000000002f26c402 7. ./src/Core/Settings.h:0: DB::BaseSettings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x000000002eed3dee 8. ./build_docker/./src/Access/SettingsConstraints.cpp:0: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x000000002eed26d1 9. ./build_docker/./src/Access/SettingsConstraints.cpp:285: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a3d 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002eed0ee2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002fc65656 12. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x00000000310cdc3d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:21.120037 [ 14973 ] {a372cb74-d0fb-4815-974d-ac1b65d9fa9c} TCPHandler: Code: 36. DB::Exception: Invalid time zone: Ðбырвалг. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Core/SettingsFields.cpp:553: DB::SettingFieldTimezone::validateTimezone(String const&) @ 0x000000002f36efde 5. ./contrib/llvm-project/libcxx/include/string:2497: DB::SettingFieldTimezone::SettingFieldTimezone(DB::Field const&) @ 0x000000002f2f944a 6. ./build_docker/./src/Core/Settings.cpp:21: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda1475'(DB::Field const&)::__invoke(DB::Field const&) @ 0x000000002f26c402 7. ./src/Core/Settings.h:0: DB::BaseSettings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x000000002eed3dee 8. ./build_docker/./src/Access/SettingsConstraints.cpp:0: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x000000002eed26d1 9. ./build_docker/./src/Access/SettingsConstraints.cpp:285: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a3d 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002eed0ee2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002fc65656 12. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x00000000310cdc3d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:21.251614 [ 11440 ] {e99a5ea2-060b-4496-b33b-f9c8a153f3d9} ExternalDictionariesLoader: Could not load external dictionary '65de6e72-d590-4369-933c-1db7d2188fea', next update is scheduled at 2025-03-05 21:09:26: Code: 36. DB::Exception: 65de6e72-d590-4369-933c-1db7d2188fea: max_load_factor parameter should be within [0.5, 0.99], got 1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, float&) @ 0x00000000295d7fd2 4. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:65: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x00000000295d6e48 5. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:127: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x00000000295d7c6d 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e831b7d 7. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830dc0 8. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 12. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:21.251914 [ 5753 ] {e99a5ea2-060b-4496-b33b-f9c8a153f3d9} executeQuery: Code: 36. DB::Exception: 65de6e72-d590-4369-933c-1db7d2188fea: max_load_factor parameter should be within [0.5, 0.99], got 1. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:50318) (comment: 02740_hashed_dictionary_load_factor_smoke.sql) (in query: -- should because of MAX_LOAD_FACTOR is 1 (maximum allowed value is 0.99) SYSTEM RELOAD DICTIONARY test_dictionary_load_factor_string;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, float&) @ 0x00000000295d7fd2 4. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:65: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x00000000295d6e48 5. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:127: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x00000000295d7c6d 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e831b7d 7. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830dc0 8. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 12. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:21.252040 [ 5753 ] {e99a5ea2-060b-4496-b33b-f9c8a153f3d9} TCPHandler: Code: 36. DB::Exception: 65de6e72-d590-4369-933c-1db7d2188fea: max_load_factor parameter should be within [0.5, 0.99], got 1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, float&) @ 0x00000000295d7fd2 4. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:65: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x00000000295d6e48 5. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:127: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x00000000295d7c6d 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e831b7d 7. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830dc0 8. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 12. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.020250 [ 14973 ] {872e0114-32dc-47f4-9396-abe8fd360344} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT caseWithExpr(arrayReduce(NULL, []), []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:50478) (comment: 02732_transform_fuzz.sql) (in query: SELECT caseWithExpr(arrayReduce(NULL, []), []);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023d95467 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:09:22.020452 [ 14973 ] {872e0114-32dc-47f4-9396-abe8fd360344} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT caseWithExpr(arrayReduce(NULL, []), []). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023d95467 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:09:22.100594 [ 14973 ] {49e6593271454a18b3f9a6af24199582} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:60888). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:60888) (in query: select 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2217: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aae9a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.100780 [ 14973 ] {49e6593271454a18b3f9a6af24199582} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:60888). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2217: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aae9a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.100987 [ 14973 ] {49e6593271454a18b3f9a6af24199582} TCPHandler: Client has gone away. 2025.03.05 21:09:22.477864 [ 14974 ] {e6855190-db69-479f-b3ef-daa1ab634285} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t FROM na FULL JOIN nb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.478252 [ 14974 ] {e6855190-db69-479f-b3ef-daa1ab634285} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.550273 [ 14974 ] {9d57c85e-8078-4ad8-91cc-c8cdffafb73c} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 'na.t' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT na.t FROM na FULL JOIN nb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cb149 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.550497 [ 14974 ] {9d57c85e-8078-4ad8-91cc-c8cdffafb73c} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 'na.t' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cb149 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.596422 [ 14974 ] {2a8c467c-e15f-4abe-b34a-505ebe6adc35} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 'nb.t' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT nb.t FROM na FULL JOIN nb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cb10c 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.596806 [ 14974 ] {2a8c467c-e15f-4abe-b34a-505ebe6adc35} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 'nb.t' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cb10c 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.729838 [ 14974 ] {498f714e-7312-4e87-95e4-3618f0186873} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't.t' while joining using column 't'. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t.t FROM (SELECT (1, 's') :: Tuple(t Int32, s String) as t ) as na FULL JOIN (SELECT (1, 's') :: Tuple(t UInt32, s String) as t ) as nb USING (t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.730075 [ 14974 ] {498f714e-7312-4e87-95e4-3618f0186873} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't.t' while joining using column 't'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.764442 [ 14974 ] {c81e7752-d90c-4813-88b0-8eaca0cb3a3a} executeQuery: Code: 1. DB::Exception: JOIN (SELECT _CAST((1, 's'), 'Tuple(t Int32, s String)') AS t FROM system.one) AS na ALL FULL OUTER JOIN (SELECT _CAST((1, 's'), 'Tuple(t UInt32, s String)') AS t FROM system.one) AS nb USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT * FROM (SELECT CAST('(1, \'s\')', 'Tuple(t Int32, s String)') AS t) AS na FULL OUTER JOIN (SELECT CAST('(1, \'s\')', 'Tuple(t UInt32, s String)') AS t) AS nb USING (t.t). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT * FROM (SELECT (1, 's') :: Tuple(t Int32, s String) as t ) as na FULL JOIN (SELECT (1, 's') :: Tuple(t UInt32, s String) as t ) as nb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.764777 [ 14974 ] {c81e7752-d90c-4813-88b0-8eaca0cb3a3a} TCPHandler: Code: 1. DB::Exception: JOIN (SELECT _CAST((1, 's'), 'Tuple(t Int32, s String)') AS t FROM system.one) AS na ALL FULL OUTER JOIN (SELECT _CAST((1, 's'), 'Tuple(t UInt32, s String)') AS t FROM system.one) AS nb USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT * FROM (SELECT CAST('(1, \'s\')', 'Tuple(t Int32, s String)') AS t) AS na FULL OUTER JOIN (SELECT CAST('(1, \'s\')', 'Tuple(t UInt32, s String)') AS t) AS nb USING (t.t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.768905 [ 14974 ] {f7c45169-8743-40ec-95ce-5da963a3375b} executeQuery: Code: 1. DB::Exception: JOIN (SELECT _CAST(((((1, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t FROM system.one) AS ttta ALL FULL OUTER JOIN (SELECT _CAST(((((2, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t FROM system.one) AS tttb USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t as e, toTypeName(e) FROM ( SELECT ((((1, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String) as t ) ttta FULL JOIN ( SELECT ((((2, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String) as t ) tttb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.769104 [ 14974 ] {f7c45169-8743-40ec-95ce-5da963a3375b} TCPHandler: Code: 1. DB::Exception: JOIN (SELECT _CAST(((((1, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t FROM system.one) AS ttta ALL FULL OUTER JOIN (SELECT _CAST(((((2, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t FROM system.one) AS tttb USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.772115 [ 14974 ] {550cf26c-bd90-4649-915a-f24cb0201352} executeQuery: Code: 1. DB::Exception: JOIN (SELECT _CAST(((((1, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t FROM system.one) AS ttta ALL FULL OUTER JOIN (SELECT _CAST(((((2, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t FROM system.one) AS tttb USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t.t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t.t as e, toTypeName(e) FROM ( SELECT ((((1, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String) as t ) ttta FULL JOIN ( SELECT ((((2, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String) as t ) tttb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.772245 [ 14974 ] {550cf26c-bd90-4649-915a-f24cb0201352} TCPHandler: Code: 1. DB::Exception: JOIN (SELECT _CAST(((((1, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t FROM system.one) AS ttta ALL FULL OUTER JOIN (SELECT _CAST(((((2, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t FROM system.one) AS tttb USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t.t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.775132 [ 14974 ] {91ff8d9f-4493-497a-91ae-cb1dd5aff7f3} executeQuery: Code: 1. DB::Exception: JOIN (SELECT _CAST(((((1, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t FROM system.one) AS ttta ALL FULL OUTER JOIN (SELECT _CAST(((((2, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t FROM system.one) AS tttb USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t.t.t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t.t.t as e, toTypeName(e) FROM ( SELECT ((((1, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String) as t ) ttta FULL JOIN ( SELECT ((((2, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String) as t ) tttb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.775278 [ 14974 ] {91ff8d9f-4493-497a-91ae-cb1dd5aff7f3} TCPHandler: Code: 1. DB::Exception: JOIN (SELECT _CAST(((((1, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t FROM system.one) AS ttta ALL FULL OUTER JOIN (SELECT _CAST(((((2, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t FROM system.one) AS tttb USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t.t.t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.784880 [ 14974 ] {eae1d7f0-f16c-4432-858e-a337dec33042} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't.t' while joining using column 't'. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t.t as e, toTypeName(e) FROM ( SELECT ((((1, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String) as t ) ttta FULL JOIN ( SELECT ((((2, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String) as t ) tttb USING (t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:22.785046 [ 14974 ] {eae1d7f0-f16c-4432-858e-a337dec33042} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't.t' while joining using column 't'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.107603 [ 14974 ] {1592eae1-a9e9-4b9f-ba5d-082db7afa5e2} executeQuery: Code: 1. DB::Exception: JOIN test_8o3kas8h.nnna ALL FULL OUTER JOIN test_8o3kas8h.nnnb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.107743 [ 14974 ] {1592eae1-a9e9-4b9f-ba5d-082db7afa5e2} TCPHandler: Code: 1. DB::Exception: JOIN test_8o3kas8h.nnna ALL FULL OUTER JOIN test_8o3kas8h.nnnb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.109976 [ 14974 ] {204ac4d4-919f-4b54-bbae-6c185e7c9b60} executeQuery: Code: 1. DB::Exception: JOIN test_8o3kas8h.nnna ALL FULL OUTER JOIN test_8o3kas8h.nnnb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t.t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.110102 [ 14974 ] {204ac4d4-919f-4b54-bbae-6c185e7c9b60} TCPHandler: Code: 1. DB::Exception: JOIN test_8o3kas8h.nnna ALL FULL OUTER JOIN test_8o3kas8h.nnnb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.112190 [ 14974 ] {1fd00896-09f3-4766-bdba-35d04cbefb6c} executeQuery: Code: 1. DB::Exception: JOIN test_8o3kas8h.nnna ALL FULL OUTER JOIN test_8o3kas8h.nnnb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t.t.t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.112317 [ 14974 ] {1fd00896-09f3-4766-bdba-35d04cbefb6c} TCPHandler: Code: 1. DB::Exception: JOIN test_8o3kas8h.nnna ALL FULL OUTER JOIN test_8o3kas8h.nnnb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.114279 [ 14974 ] {2ad3e7bb-769b-46ed-bbb3-4258cb729920} executeQuery: Code: 1. DB::Exception: JOIN test_8o3kas8h.nnna ALL FULL OUTER JOIN test_8o3kas8h.nnnb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t.t.t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t.t.t.t.t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.114400 [ 14974 ] {2ad3e7bb-769b-46ed-bbb3-4258cb729920} TCPHandler: Code: 1. DB::Exception: JOIN test_8o3kas8h.nnna ALL FULL OUTER JOIN test_8o3kas8h.nnnb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t.t.t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.116939 [ 14974 ] {bbcefa52-e01c-48d6-9834-f7891983699d} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.117085 [ 14974 ] {bbcefa52-e01c-48d6-9834-f7891983699d} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.175926 [ 14974 ] {9aae1598-5763-4683-bdeb-6050e7ead46c} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t.*, t.* APPLY toTypeName FROM nnna FULL JOIN nnnb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::(anonymous namespace)::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308e6ac7 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882ced 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.176212 [ 14974 ] {9aae1598-5763-4683-bdeb-6050e7ead46c} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::(anonymous namespace)::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308e6ac7 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882ced 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.345537 [ 14974 ] {ffdda8ce-ec64-4ff7-a1e5-a706e5af7e0a} executeQuery: Code: 1. DB::Exception: JOIN test_8o3kas8h.na ALL FULL OUTER JOIN test_8o3kas8h.nb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT 1 FROM na FULL OUTER JOIN nb USING (t). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT 1 FROM na FULL JOIN nb USING (t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.345665 [ 14974 ] {ffdda8ce-ec64-4ff7-a1e5-a706e5af7e0a} TCPHandler: Code: 1. DB::Exception: JOIN test_8o3kas8h.na ALL FULL OUTER JOIN test_8o3kas8h.nb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT 1 FROM na FULL OUTER JOIN nb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.383305 [ 14974 ] {71514a0f-bf00-4e8f-9f51-7e5263fc68da} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t FROM na FULL JOIN nb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.383577 [ 14974 ] {71514a0f-bf00-4e8f-9f51-7e5263fc68da} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.401585 [ 14974 ] {97db9428-ca00-473b-8a7e-195e1bd8b32b} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 'na.t' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT na.t FROM na FULL JOIN nb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cb149 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.401717 [ 14974 ] {97db9428-ca00-473b-8a7e-195e1bd8b32b} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 'na.t' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cb149 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.410664 [ 14974 ] {49115061-7466-469b-95d2-a62cc2d9152c} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 'nb.t' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT nb.t FROM na FULL JOIN nb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cb10c 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.410871 [ 14974 ] {49115061-7466-469b-95d2-a62cc2d9152c} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 'nb.t' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cb10c 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.515405 [ 14974 ] {c1f95e5e-d961-4ef4-a63b-80e86434ef12} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't.t' while joining using column 't'. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t.t FROM (SELECT (1, 's') :: Tuple(t Int32, s String) as t ) as na FULL JOIN (SELECT (1, 's') :: Tuple(t UInt32, s String) as t ) as nb USING (t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.515559 [ 14974 ] {c1f95e5e-d961-4ef4-a63b-80e86434ef12} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't.t' while joining using column 't'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.517823 [ 14974 ] {6f9a1438-db3a-4ac7-b3a8-a172716f4cd2} executeQuery: Code: 1. DB::Exception: JOIN (SELECT _CAST((1, 's'), 'Tuple(t Int32, s String)') AS t FROM system.one) AS na ALL FULL OUTER JOIN (SELECT _CAST((1, 's'), 'Tuple(t UInt32, s String)') AS t FROM system.one) AS nb USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT * FROM (SELECT CAST('(1, \'s\')', 'Tuple(t Int32, s String)') AS t) AS na FULL OUTER JOIN (SELECT CAST('(1, \'s\')', 'Tuple(t UInt32, s String)') AS t) AS nb USING (t.t). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT * FROM (SELECT (1, 's') :: Tuple(t Int32, s String) as t ) as na FULL JOIN (SELECT (1, 's') :: Tuple(t UInt32, s String) as t ) as nb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.518005 [ 14974 ] {6f9a1438-db3a-4ac7-b3a8-a172716f4cd2} TCPHandler: Code: 1. DB::Exception: JOIN (SELECT _CAST((1, 's'), 'Tuple(t Int32, s String)') AS t FROM system.one) AS na ALL FULL OUTER JOIN (SELECT _CAST((1, 's'), 'Tuple(t UInt32, s String)') AS t FROM system.one) AS nb USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT * FROM (SELECT CAST('(1, \'s\')', 'Tuple(t Int32, s String)') AS t) AS na FULL OUTER JOIN (SELECT CAST('(1, \'s\')', 'Tuple(t UInt32, s String)') AS t) AS nb USING (t.t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.520845 [ 14974 ] {d8dbc11e-5e2d-4dd6-a938-e28ffe894e0e} executeQuery: Code: 1. DB::Exception: JOIN (SELECT _CAST(((((1, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t FROM system.one) AS ttta ALL FULL OUTER JOIN (SELECT _CAST(((((2, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t FROM system.one) AS tttb USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t as e, toTypeName(e) FROM ( SELECT ((((1, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String) as t ) ttta FULL JOIN ( SELECT ((((2, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String) as t ) tttb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.521021 [ 14974 ] {d8dbc11e-5e2d-4dd6-a938-e28ffe894e0e} TCPHandler: Code: 1. DB::Exception: JOIN (SELECT _CAST(((((1, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t FROM system.one) AS ttta ALL FULL OUTER JOIN (SELECT _CAST(((((2, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t FROM system.one) AS tttb USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.523668 [ 14974 ] {4118eb48-7149-4c5a-a666-0764b214ec23} executeQuery: Code: 1. DB::Exception: JOIN (SELECT _CAST(((((1, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t FROM system.one) AS ttta ALL FULL OUTER JOIN (SELECT _CAST(((((2, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t FROM system.one) AS tttb USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t.t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t.t as e, toTypeName(e) FROM ( SELECT ((((1, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String) as t ) ttta FULL JOIN ( SELECT ((((2, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String) as t ) tttb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.523808 [ 14974 ] {4118eb48-7149-4c5a-a666-0764b214ec23} TCPHandler: Code: 1. DB::Exception: JOIN (SELECT _CAST(((((1, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t FROM system.one) AS ttta ALL FULL OUTER JOIN (SELECT _CAST(((((2, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t FROM system.one) AS tttb USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t.t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.526646 [ 14974 ] {3cb73a73-4c54-48eb-9c33-3d2c70a07e1d} executeQuery: Code: 1. DB::Exception: JOIN (SELECT _CAST(((((1, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t FROM system.one) AS ttta ALL FULL OUTER JOIN (SELECT _CAST(((((2, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t FROM system.one) AS tttb USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t.t.t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t.t.t as e, toTypeName(e) FROM ( SELECT ((((1, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String) as t ) ttta FULL JOIN ( SELECT ((((2, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String) as t ) tttb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.526822 [ 14974 ] {3cb73a73-4c54-48eb-9c33-3d2c70a07e1d} TCPHandler: Code: 1. DB::Exception: JOIN (SELECT _CAST(((((1, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t FROM system.one) AS ttta ALL FULL OUTER JOIN (SELECT _CAST(((((2, 's'), 's'), 's'), 's'), 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t FROM system.one) AS tttb USING (t.t) using identifier 't.t' must be resolved into column node from left table expression. In scope SELECT t.t.t AS e, toTypeName(e) FROM (SELECT CAST('((((1, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String)') AS t) AS ttta FULL OUTER JOIN (SELECT CAST('((((2, \'s\'), \'s\'), \'s\'), \'s\')', 'Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String)') AS t) AS tttb USING (t.t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.535748 [ 14974 ] {eaf96e3f-1b69-4f98-9874-6b4827c88f38} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't.t' while joining using column 't'. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t.t as e, toTypeName(e) FROM ( SELECT ((((1, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t UInt32, s String), s String), s String), s String) as t ) ttta FULL JOIN ( SELECT ((((2, 's'), 's'), 's'), 's') :: Tuple(t Tuple(t Tuple(t Tuple(t Int32, s String), s String), s String), s String) as t ) tttb USING (t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.535916 [ 14974 ] {eaf96e3f-1b69-4f98-9874-6b4827c88f38} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't.t' while joining using column 't'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.811736 [ 14974 ] {9ea7d5cd-6147-4602-bce2-5d7812b3e790} executeQuery: Code: 1. DB::Exception: JOIN test_8o3kas8h.nnna ALL FULL OUTER JOIN test_8o3kas8h.nnnb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.811866 [ 14974 ] {9ea7d5cd-6147-4602-bce2-5d7812b3e790} TCPHandler: Code: 1. DB::Exception: JOIN test_8o3kas8h.nnna ALL FULL OUTER JOIN test_8o3kas8h.nnnb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.813382 [ 14974 ] {b565138d-6092-47e9-bb4f-8a94095646de} executeQuery: Code: 1. DB::Exception: JOIN test_8o3kas8h.nnna ALL FULL OUTER JOIN test_8o3kas8h.nnnb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t.t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.813493 [ 14974 ] {b565138d-6092-47e9-bb4f-8a94095646de} TCPHandler: Code: 1. DB::Exception: JOIN test_8o3kas8h.nnna ALL FULL OUTER JOIN test_8o3kas8h.nnnb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.815002 [ 14974 ] {62452189-5604-4cea-ad24-21a3c678c69b} executeQuery: Code: 1. DB::Exception: JOIN test_8o3kas8h.nnna ALL FULL OUTER JOIN test_8o3kas8h.nnnb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t.t.t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.815109 [ 14974 ] {62452189-5604-4cea-ad24-21a3c678c69b} TCPHandler: Code: 1. DB::Exception: JOIN test_8o3kas8h.nnna ALL FULL OUTER JOIN test_8o3kas8h.nnnb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.816657 [ 14974 ] {31306d96-8f75-4ce2-9918-819cfc03ac91} executeQuery: Code: 1. DB::Exception: JOIN test_8o3kas8h.nnna ALL FULL OUTER JOIN test_8o3kas8h.nnnb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t.t.t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t.t.t.t.t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.816781 [ 14974 ] {31306d96-8f75-4ce2-9918-819cfc03ac91} TCPHandler: Code: 1. DB::Exception: JOIN test_8o3kas8h.nnna ALL FULL OUTER JOIN test_8o3kas8h.nnnb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT t.t.t.t.t AS e, toTypeName(e) FROM nnna FULL OUTER JOIN nnnb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.818435 [ 14974 ] {1f165f0f-96a4-4187-b202-773179b575cd} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t as e, toTypeName(e) FROM nnna FULL JOIN nnnb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.818546 [ 14974 ] {1f165f0f-96a4-4187-b202-773179b575cd} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.837662 [ 14974 ] {3d84c559-e675-4671-b354-2c0b560a329d} executeQuery: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT t.*, t.* APPLY toTypeName FROM nnna FULL JOIN nnnb USING (t.t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::(anonymous namespace)::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308e6ac7 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882ced 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.837775 [ 14974 ] {3d84c559-e675-4671-b354-2c0b560a329d} TCPHandler: Code: 207. DB::Exception: Cannot select subcolumn for identifier 't' while joining using column 't.t'. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::Identifier const&, String const&) @ 0x000000003091b71b 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3508: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&) const @ 0x00000000308cead4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ca845 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::(anonymous namespace)::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308e6ac7 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882ced 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.968419 [ 14974 ] {61b0167d-a83f-4fa3-b2fd-d58f4886e460} executeQuery: Code: 1. DB::Exception: JOIN test_8o3kas8h.na ALL FULL OUTER JOIN test_8o3kas8h.nb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT 1 FROM na FULL OUTER JOIN nb USING (t). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:50530) (comment: 02731_analyzer_join_resolve_nested.gen.sql) (in query: SELECT 1 FROM na FULL JOIN nb USING (t);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:23.968560 [ 14974 ] {61b0167d-a83f-4fa3-b2fd-d58f4886e460} TCPHandler: Code: 1. DB::Exception: JOIN test_8o3kas8h.na ALL FULL OUTER JOIN test_8o3kas8h.nb USING (t) using identifier 't' must be resolved into column node from left table expression. In scope SELECT 1 FROM na FULL OUTER JOIN nb USING (t). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dfe45 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:24.792464 [ 3522 ] {88f71765-f76a-4383-8e17-ba09ec3e32e8} BackupsWorker: Failed to make backup Disk('backups', 'test_s3_backup'): Code: 598. DB::Exception: Backup Disk('backups', 'test_s3_backup') already exists. (BACKUP_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::checkBackupDoesntExist() const @ 0x000000002f01d93a 5. ./build_docker/./src/Backups/BackupImpl.cpp:186: DB::BackupImpl::open() @ 0x000000002f019fc7 6. ./build_docker/./src/Backups/BackupImpl.cpp:142: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool) @ 0x000000002f01bc1f 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, std::shared_ptr&, std::shared_ptr const&, bool const&, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool const&, bool const&>(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams&, std::optional const&, std::shared_ptr&, std::shared_ptr const&, bool const&, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool const&, bool const&) @ 0x000000002f0e9a6f 8. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:189: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002f0e8011 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:470: ? @ 0x000000002f0e63d1 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x000000002ef645f8 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002ef5f5a6 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002ef5e952 13. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000317d3459 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:24.792875 [ 3522 ] {88f71765-f76a-4383-8e17-ba09ec3e32e8} executeQuery: Code: 598. DB::Exception: Backup Disk('backups', 'test_s3_backup') already exists. (BACKUP_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:50820) (comment: 02731_zero_objects_in_metadata.sh) (in query: BACKUP TABLE test TO Disk('backups', 'test_s3_backup');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::checkBackupDoesntExist() const @ 0x000000002f01d93a 5. ./build_docker/./src/Backups/BackupImpl.cpp:186: DB::BackupImpl::open() @ 0x000000002f019fc7 6. ./build_docker/./src/Backups/BackupImpl.cpp:142: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool) @ 0x000000002f01bc1f 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, std::shared_ptr&, std::shared_ptr const&, bool const&, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool const&, bool const&>(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams&, std::optional const&, std::shared_ptr&, std::shared_ptr const&, bool const&, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool const&, bool const&) @ 0x000000002f0e9a6f 8. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:189: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002f0e8011 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:470: ? @ 0x000000002f0e63d1 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x000000002ef645f8 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002ef5f5a6 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002ef5e952 13. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000317d3459 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:24.793220 [ 3522 ] {88f71765-f76a-4383-8e17-ba09ec3e32e8} TCPHandler: Code: 598. DB::Exception: Backup Disk('backups', 'test_s3_backup') already exists. (BACKUP_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::checkBackupDoesntExist() const @ 0x000000002f01d93a 5. ./build_docker/./src/Backups/BackupImpl.cpp:186: DB::BackupImpl::open() @ 0x000000002f019fc7 6. ./build_docker/./src/Backups/BackupImpl.cpp:142: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool) @ 0x000000002f01bc1f 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, std::shared_ptr&, std::shared_ptr const&, bool const&, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool const&, bool const&>(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams&, std::optional const&, std::shared_ptr&, std::shared_ptr const&, bool const&, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool const&, bool const&) @ 0x000000002f0e9a6f 8. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:189: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002f0e8011 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:470: ? @ 0x000000002f0e63d1 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x000000002ef645f8 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002ef5f5a6 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002ef5e952 13. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000317d3459 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:25.242238 [ 14920 ] {4bf661dd-63c0-4aa3-bfef-53bd542107b8} executeQuery: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 3390450000 microseconds per block (of size 67809): while executing 'FUNCTION sleepEachRow(0.05_Float64 :: 1) -> sleepEachRow(0.05_Float64) UInt8 : 0'. (TOO_SLOW) (version 24.3.12.76.altinitystable) (from [::1]:50904) (comment: 02725_sleep_max_time.sql) (in query: SELECT * FROM system.numbers WHERE sleepEachRow(0.05) LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x0000000021622709 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x0000000021624e35 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021623d5a 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000033b59e3a 13. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:265: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000033b598fa 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:25.242408 [ 14920 ] {4bf661dd-63c0-4aa3-bfef-53bd542107b8} TCPHandler: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 3390450000 microseconds per block (of size 67809): while executing 'FUNCTION sleepEachRow(0.05_Float64 :: 1) -> sleepEachRow(0.05_Float64) UInt8 : 0'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x0000000021622709 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x0000000021624e35 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021623d5a 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000033b59e3a 13. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:265: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000033b598fa 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:26.903989 [ 14920 ] {cb96478f-9ea1-413b-903f-ad88a7961ed4} executeQuery: Code: 42. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:51154) (comment: 02718_array_fold.sql) (in query: SELECT arrayFold();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023ce3504 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:26.904171 [ 14920 ] {cb96478f-9ea1-413b-903f-ad88a7961ed4} TCPHandler: Code: 42. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023ce3504 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:26.906057 [ 14920 ] {645edffe-4340-4eff-8bdb-d7ffb05bbbcb} executeQuery: Code: 42. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:51154) (comment: 02718_array_fold.sql) (in query: SELECT arrayFold(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023ce3504 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:26.906159 [ 14920 ] {645edffe-4340-4eff-8bdb-d7ffb05bbbcb} TCPHandler: Code: 42. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023ce3504 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:26.907751 [ 14920 ] {0472522c-5f8a-411b-8a8f-53b497f18009} executeQuery: Code: 42. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(1, toUInt64(0)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:51154) (comment: 02718_array_fold.sql) (in query: SELECT arrayFold(1, toUInt64(0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023ce3504 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:26.907866 [ 14920 ] {0472522c-5f8a-411b-8a8f-53b497f18009} TCPHandler: Code: 42. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(1, toUInt64(0)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023ce3504 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:26.933104 [ 14920 ] {99407350-6f0f-4f18-afcb-d8d4504f9311} executeQuery: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold(1, emptyArrayUInt64(), toUInt64(0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:51154) (comment: 02718_array_fold.sql) (in query: SELECT arrayFold(1, emptyArrayUInt64(), toUInt64(0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023ce360a 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:26.933327 [ 14920 ] {99407350-6f0f-4f18-afcb-d8d4504f9311} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold(1, emptyArrayUInt64(), toUInt64(0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023ce360a 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:26.958424 [ 14920 ] {91a26ca8-e744-480f-a7b5-306053c3c0c7} executeQuery: Code: 53. DB::Exception: Return type of lambda function must be the same as the accumulator type, inferred return type of lambda: String, inferred type of accumulator: Int8: In scope SELECT arrayFold((acc, x) -> x, emptyArrayString(), toInt8(0)). (TYPE_MISMATCH) (version 24.3.12.76.altinitystable) (from [::1]:51154) (comment: 02718_array_fold.sql) (in query: SELECT arrayFold( acc,x -> x, emptyArrayString(), toInt8(0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023ce37f6 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:26.958652 [ 14920 ] {91a26ca8-e744-480f-a7b5-306053c3c0c7} TCPHandler: Code: 53. DB::Exception: Return type of lambda function must be the same as the accumulator type, inferred return type of lambda: String, inferred type of accumulator: Int8: In scope SELECT arrayFold((acc, x) -> x, emptyArrayString(), toInt8(0)). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionArrayFold::getReturnTypeImpl(std::vector> const&) const @ 0x0000000023ce37f6 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:26.984447 [ 14920 ] {97bd7b9b-b791-4fd9-aac6-8f18c0a0683c} executeQuery: Code: 43. DB::Exception: Argument 2 of function arrayFold must be of type Array, found String instead. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:51154) (comment: 02718_array_fold.sql) (in query: SELECT arrayFold( acc,x -> x, 'not an array', toUInt8(0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&) @ 0x0000000020165b51 4. DB::FunctionArrayFold::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000023ce4118 5. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ae00b 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:26.984697 [ 14920 ] {97bd7b9b-b791-4fd9-aac6-8f18c0a0683c} TCPHandler: Code: 43. DB::Exception: Argument 2 of function arrayFold must be of type Array, found String instead. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&) @ 0x0000000020165b51 4. DB::FunctionArrayFold::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000023ce4118 5. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ae00b 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:26.987028 [ 14920 ] {84110026-57b9-495b-83f4-eed6830c4525} executeQuery: Code: 43. DB::Exception: Argument 3 of function arrayFold must be of type Array, found String instead. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:51154) (comment: 02718_array_fold.sql) (in query: SELECT arrayFold( acc,x,y -> x, [0, 1], 'not an array', toUInt8(0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&) @ 0x0000000020165b51 4. DB::FunctionArrayFold::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000023ce4118 5. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ae00b 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:26.987135 [ 14920 ] {84110026-57b9-495b-83f4-eed6830c4525} TCPHandler: Code: 43. DB::Exception: Argument 3 of function arrayFold must be of type Array, found String instead. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&) @ 0x0000000020165b51 4. DB::FunctionArrayFold::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000023ce4118 5. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ae00b 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:27.010009 [ 14920 ] {33011c2d-8047-4b63-91ae-8d8e51421dbd} executeQuery: Code: 43. DB::Exception: First argument of function arrayFold must be a lambda function with 3 arguments, found Function((?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:51154) (comment: 02718_array_fold.sql) (in query: SELECT arrayFold( acc,x -> x, [0, 1], [2, 3], toUInt8(0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000018082175 4. DB::FunctionArrayFold::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000023ce4323 5. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ae00b 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:27.010228 [ 14920 ] {33011c2d-8047-4b63-91ae-8d8e51421dbd} TCPHandler: Code: 43. DB::Exception: First argument of function arrayFold must be a lambda function with 3 arguments, found Function((?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000018082175 4. DB::FunctionArrayFold::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000023ce4323 5. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ae00b 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:27.029707 [ 14920 ] {f1be48a1-2ad3-4970-b815-48b4a48f75c4} executeQuery: Code: 190. DB::Exception: arrays_data_with_type_and_name passed to arrayFold must have equal size: while executing 'FUNCTION arrayFold(acc UInt8, x UInt8, y UInt8 -> x :: 1, _CAST([0, 1]_Array(UInt8), 'Array(UInt8)'_String) :: 2, _CAST([2, 3, 4]_Array(UInt8), 'Array(UInt8)'_String) :: 3, _CAST(0_UInt8, 'UInt8'_String) :: 4) -> arrayFold(acc UInt8, x UInt8, y UInt8 -> x, _CAST([0, 1]_Array(UInt8), 'Array(UInt8)'_String), _CAST([2, 3, 4]_Array(UInt8), 'Array(UInt8)'_String), _CAST(0_UInt8, 'UInt8'_String)) UInt8 : 5'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:51154) (comment: 02718_array_fold.sql) (in query: SELECT arrayFold( acc,x,y -> x, [0, 1], [2, 3, 4], toUInt8(0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayFold::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023ce24c9 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:27.029908 [ 14920 ] {f1be48a1-2ad3-4970-b815-48b4a48f75c4} TCPHandler: Code: 190. DB::Exception: arrays_data_with_type_and_name passed to arrayFold must have equal size: while executing 'FUNCTION arrayFold(acc UInt8, x UInt8, y UInt8 -> x :: 1, _CAST([0, 1]_Array(UInt8), 'Array(UInt8)'_String) :: 2, _CAST([2, 3, 4]_Array(UInt8), 'Array(UInt8)'_String) :: 3, _CAST(0_UInt8, 'UInt8'_String) :: 4) -> arrayFold(acc UInt8, x UInt8, y UInt8 -> x, _CAST([0, 1]_Array(UInt8), 'Array(UInt8)'_String), _CAST([2, 3, 4]_Array(UInt8), 'Array(UInt8)'_String), _CAST(0_UInt8, 'UInt8'_String)) UInt8 : 5'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayFold::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023ce24c9 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:27.181415 [ 14973 ] {acbd5bf2-d7ed-438a-81d9-823131037b98} executeQuery: Code: 692. DB::Exception: Too many unfinished mutations (2) in table test_9xxd3bi2.t_limit_mutations (920d0707-401c-4a1a-8270-341489f35f9d). (TOO_MANY_MUTATIONS) (version 24.3.12.76.altinitystable) (from [::1]:51186) (comment: 02724_limit_num_mutations.sh) (in query: ALTER TABLE t_limit_mutations UPDATE v = 5 WHERE 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayMutationOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&) const @ 0x0000000032b70061 5. ./contrib/llvm-project/libcxx/include/__tree:1097: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000324e5233 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:27.181635 [ 14973 ] {acbd5bf2-d7ed-438a-81d9-823131037b98} TCPHandler: Code: 692. DB::Exception: Too many unfinished mutations (2) in table test_9xxd3bi2.t_limit_mutations (920d0707-401c-4a1a-8270-341489f35f9d). (TOO_MANY_MUTATIONS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayMutationOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&) const @ 0x0000000032b70061 5. ./contrib/llvm-project/libcxx/include/__tree:1097: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000324e5233 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:27.203064 [ 14973 ] {52a0f040-6791-43dd-9184-72785fcf7359} executeQuery: Code: 692. DB::Exception: Too many unfinished mutations (2) in table test_9xxd3bi2.t_limit_mutations (920d0707-401c-4a1a-8270-341489f35f9d). (TOO_MANY_MUTATIONS) (version 24.3.12.76.altinitystable) (from [::1]:51186) (comment: 02724_limit_num_mutations.sh) (in query: ALTER TABLE t_limit_mutations MODIFY COLUMN v String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayMutationOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&) const @ 0x0000000032b70061 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6186: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000324a688f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795294 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:27.203245 [ 14973 ] {52a0f040-6791-43dd-9184-72785fcf7359} TCPHandler: Code: 692. DB::Exception: Too many unfinished mutations (2) in table test_9xxd3bi2.t_limit_mutations (920d0707-401c-4a1a-8270-341489f35f9d). (TOO_MANY_MUTATIONS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayMutationOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&) const @ 0x0000000032b70061 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6186: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000324a688f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795294 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:27.649197 [ 14920 ] {fc51300d-a143-4d6e-b971-99ec4017eab9} executeQuery: Code: 705. DB::Exception: Table data_02716_1 is not empty. (TABLE_NOT_EMPTY) (version 24.3.12.76.altinitystable) (from [::1]:51244) (comment: 02716_drop_if_empty.sql) (in query: DROP TABLE IF EMPTY data_02716_1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000307f7763 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:103: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000307f3e26 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000307f29e2 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:27.649347 [ 14920 ] {fc51300d-a143-4d6e-b971-99ec4017eab9} TCPHandler: Code: 705. DB::Exception: Table data_02716_1 is not empty. (TABLE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000307f7763 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:103: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000307f3e26 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000307f29e2 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:27.675489 [ 14920 ] {2c84b200-a539-4608-abf1-05d72bd6b60e} executeQuery: Code: 48. DB::Exception: DROP IF EMPTY is not implemented for databases. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:51244) (comment: 02716_drop_if_empty.sql) (in query: DROP DATABASE IF EMPTY test_0q5segbe_1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:375: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000307fa83d 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000307f402b 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:84: DB::InterpreterDropQuery::execute() @ 0x00000000307f2f15 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:27.675676 [ 14920 ] {2c84b200-a539-4608-abf1-05d72bd6b60e} TCPHandler: Code: 48. DB::Exception: DROP IF EMPTY is not implemented for databases. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:375: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000307fa83d 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000307f402b 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:84: DB::InterpreterDropQuery::execute() @ 0x00000000307f2f15 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:27.907238 [ 14974 ] {be977dc3-4332-4cc0-b877-6e8cdd8cce7d} executeQuery: Code: 36. DB::Exception: 'lifetime' parameter is redundant for the dictionary' of layout 'direct'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:51294) (comment: 02716_create_direct_dict_with_lifetime_throws.sql) (in query: CREATE DICTIONARY dict(`key` UInt64,`value` String) PRIMARY KEY key SOURCE(CLICKHOUSE(table 'dict_source')) LAYOUT(DIRECT()) LIFETIME(0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:584: DB::checkLifetime(DB::ASTCreateQuery const&) @ 0x000000002f6e07ba 5. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:0: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x000000002f6e0df5 6. ./build_docker/./src/Storages/StorageDictionary.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000032182bce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:27.907539 [ 14974 ] {be977dc3-4332-4cc0-b877-6e8cdd8cce7d} TCPHandler: Code: 36. DB::Exception: 'lifetime' parameter is redundant for the dictionary' of layout 'direct'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:584: DB::checkLifetime(DB::ASTCreateQuery const&) @ 0x000000002f6e07ba 5. ./build_docker/./src/Dictionaries/getDictionaryConfigurationFromAST.cpp:0: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x000000002f6e0df5 6. ./build_docker/./src/Storages/StorageDictionary.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000032182bce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.113195 [ 14920 ] {fc66f429-6352-4d4e-92b7-70126ae319b5} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function bitAnd: In scope SELECT bitAnd(1., 1.). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:51320) (comment: 02715_bit_operations_float.sql) (in query: SELECT bitAnd(1.0, 1.0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001996f514 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.113375 [ 14920 ] {fc66f429-6352-4d4e-92b7-70126ae319b5} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function bitAnd: In scope SELECT bitAnd(1., 1.). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001996f514 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.138714 [ 14920 ] {000b5fda-7f33-4c4f-ab92-1f771c442451} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function bitOr: In scope SELECT bitOr(1., 1.). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:51320) (comment: 02715_bit_operations_float.sql) (in query: SELECT bitOr(1.0, 1.0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019ff5f94 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.138904 [ 14920 ] {000b5fda-7f33-4c4f-ab92-1f771c442451} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function bitOr: In scope SELECT bitOr(1., 1.). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019ff5f94 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.164504 [ 14920 ] {66dffd56-16f3-4f08-9244-dbbe7972d650} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateLeft: In scope SELECT bitRotateLeft(1., 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:51320) (comment: 02715_bit_operations_float.sql) (in query: SELECT bitRotateLeft(1.0, 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a14aff4 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.164725 [ 14920 ] {66dffd56-16f3-4f08-9244-dbbe7972d650} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateLeft: In scope SELECT bitRotateLeft(1., 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a14aff4 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.190244 [ 14920 ] {63845ba5-7668-4b6b-993b-23401cf845f0} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftLeft: In scope SELECT bitShiftLeft(1., 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:51320) (comment: 02715_bit_operations_float.sql) (in query: SELECT bitShiftLeft(1.0, 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a417c74 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.190449 [ 14920 ] {63845ba5-7668-4b6b-993b-23401cf845f0} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftLeft: In scope SELECT bitShiftLeft(1., 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a417c74 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.216113 [ 14920 ] {6f6582db-4bd5-4e3f-a028-d7b6e7f72fd1} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitTest: In scope SELECT bitTest(1., 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:51320) (comment: 02715_bit_operations_float.sql) (in query: SELECT bitTest(1.0, 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a6f2a94 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.216325 [ 14920 ] {6f6582db-4bd5-4e3f-a028-d7b6e7f72fd1} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitTest: In scope SELECT bitTest(1., 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a6f2a94 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.512099 [ 14973 ] {ac0bbef0-43ed-41f1-8d2a-81727877b14b} executeQuery: Code: 44. DB::Exception: Column of type FixedString is not supported by soundex function: In scope SELECT soundex(toFixedString('Smith', 5)). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:51396) (comment: 02711_soundex_function.sql) (in query: -- negative tests SELECT soundex(toFixedString('Smith', 5));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::SoundexImpl::vectorFixed(DB::PODArray, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&) @ 0x000000002162d10e 5. DB::FunctionStringToString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002162c7c4 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:28.512332 [ 14973 ] {ac0bbef0-43ed-41f1-8d2a-81727877b14b} TCPHandler: Code: 44. DB::Exception: Column of type FixedString is not supported by soundex function: In scope SELECT soundex(toFixedString('Smith', 5)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::SoundexImpl::vectorFixed(DB::PODArray, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&) @ 0x000000002162d10e 5. DB::FunctionStringToString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002162c7c4 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:28.538776 [ 14973 ] {99ac3956-b267-4b94-8900-a228a5137861} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function soundex: In scope SELECT soundex(5). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:51396) (comment: 02711_soundex_function.sql) (in query: SELECT soundex(5);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionStringToString::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002162cc36 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.539014 [ 14973 ] {99ac3956-b267-4b94-8900-a228a5137861} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function soundex: In scope SELECT soundex(5). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionStringToString::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002162cc36 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.868502 [ 14973 ] {9cbeccee-70b0-4333-bda1-ef654272fdcf} executeQuery: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:51426) (comment: 02710_allow_suspicious_indices.sql) (in query: CREATE TABLE tbl (`id` UInt32) ENGINE = MergeTree ORDER BY (id + 1, id + 1) SETTINGS index_granularity = 8504, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 265240216, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 5123203, merge_max_block_size = 22754, old_parts_lifetime = 30., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 30656180, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 50577, primary_key_compress_block_size = 98161), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:204: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x0000000032af24bd 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:583: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032aef78e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 10. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 12. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.868920 [ 14973 ] {9cbeccee-70b0-4333-bda1-ef654272fdcf} TCPHandler: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:204: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x0000000032af24bd 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:583: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032aef78e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 10. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 12. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.916032 [ 14973 ] {0f412c36-5e5b-4240-9f09-a383c92b80e9} executeQuery: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:51426) (comment: 02710_allow_suspicious_indices.sql) (in query: CREATE TABLE tbl (`id` UInt32, INDEX idx (id + 1, id + 1) TYPE minmax GRANULARITY 1) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 8504, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 265240216, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 5123203, merge_max_block_size = 22754, old_parts_lifetime = 30., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 30656180, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 50577, primary_key_compress_block_size = 98161), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:204: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x0000000032af24bd 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:658: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af08e4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 10. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 12. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.916396 [ 14973 ] {0f412c36-5e5b-4240-9f09-a383c92b80e9} TCPHandler: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:204: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x0000000032af24bd 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:658: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af08e4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 10. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 12. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.958287 [ 14973 ] {6641410b-709b-453b-8a9d-08eeaecc8efe} executeQuery: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:51426) (comment: 02710_allow_suspicious_indices.sql) (in query: ALTER TABLE tbl ADD COLUMN `id2` UInt32, MODIFY ORDER BY (id1, id2, id2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:204: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x0000000032af24bd 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:583: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032aef78e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3410: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40c96 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.958550 [ 14973 ] {6641410b-709b-453b-8a9d-08eeaecc8efe} TCPHandler: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:204: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x0000000032af24bd 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:583: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032aef78e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3410: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40c96 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.961349 [ 14973 ] {1c813b46-7e00-4c2f-894e-0f146557edf9} executeQuery: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:51426) (comment: 02710_allow_suspicious_indices.sql) (in query: ALTER TABLE tbl ADD COLUMN `id2` UInt32, MODIFY ORDER BY (id1, id2, id1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:204: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x0000000032af24bd 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:583: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032aef78e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3410: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40c96 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.961487 [ 14973 ] {1c813b46-7e00-4c2f-894e-0f146557edf9} TCPHandler: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:204: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x0000000032af24bd 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:583: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032aef78e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3410: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40c96 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.994357 [ 14973 ] {1a67ee45-ee69-4051-ba9e-7aba668dd8f8} executeQuery: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:51426) (comment: 02710_allow_suspicious_indices.sql) (in query: ALTER TABLE tbl ADD INDEX idx (id+1, id, id+1) TYPE minmax;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:204: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x0000000032af24bd 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:658: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af08e4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3410: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40c96 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:28.994525 [ 14973 ] {1a67ee45-ee69-4051-ba9e-7aba668dd8f8} TCPHandler: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:204: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x0000000032af24bd 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:658: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af08e4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3410: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40c96 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:29.381212 [ 14973 ] {e36589a1-1a35-4c86-b09f-f2c548c960a6} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:56730) (comment: 02707_skip_index_with_in.sql) (in query: EXPLAIN SELECT count() FROM t_skip_index_in WHERE c IN (SELECT throwIf(1)) SETTINGS use_skip_indexes = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/PreparedSets.cpp:225: DB::FutureSetFromSubquery::buildOrderedSetInplace(std::shared_ptr const&) @ 0x000000003118c514 20. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexConditionBloomFilter.cpp:295: DB::MergeTreeIndexConditionBloomFilter::traverseFunction(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&, DB::RPNBuilderTreeNode const*) @ 0x0000000032d1e39e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexConditionBloomFilter.cpp:266: DB::MergeTreeIndexConditionBloomFilter::extractAtomFromTree(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&) @ 0x0000000032d1e0e0 22. ./src/Storages/MergeTree/RPNBuilder.h:242: DB::RPNBuilder::traverseTree(DB::RPNBuilderTreeNode const&) @ 0x0000000032d35e9b 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032d1c248 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeIndexConditionBloomFilter* std::construct_at[abi:v15000] const&, std::shared_ptr&, DB::Block const&, unsigned long const&, DB::MergeTreeIndexConditionBloomFilter*>(DB::MergeTreeIndexConditionBloomFilter*, std::shared_ptr const&, std::shared_ptr&, DB::Block const&, unsigned long const&) @ 0x0000000032d10ca7 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000] const&, std::shared_ptr&, DB::Block const&, unsigned long const&>(std::allocator, std::shared_ptr const&, std::shared_ptr&, DB::Block const&, unsigned long const&) @ 0x0000000032d1072a 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr const&, std::shared_ptr&, DB::Block const&, unsigned long const&, void>(std::allocator const&, std::shared_ptr const&, std::shared_ptr&, DB::Block const&, unsigned long const&) @ 0x0000000032d104d2 27. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:48: DB::MergeTreeIndexBloomFilter::createIndexCondition(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032d0e78e 28. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildIndexes(std::optional&, std::shared_ptr, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) @ 0x0000000033f3e75a 29. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1546: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x0000000033f3d429 30. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000003400c97b 31. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyCondition.cpp:41: DB::QueryPlanOptimizations::optimizePrimaryKeyCondition(std::vector> const&) @ 0x000000003400c5e1 2025.03.05 21:09:29.381452 [ 14973 ] {e36589a1-1a35-4c86-b09f-f2c548c960a6} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 19. ./build_docker/./src/Interpreters/PreparedSets.cpp:225: DB::FutureSetFromSubquery::buildOrderedSetInplace(std::shared_ptr const&) @ 0x000000003118c514 20. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexConditionBloomFilter.cpp:295: DB::MergeTreeIndexConditionBloomFilter::traverseFunction(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&, DB::RPNBuilderTreeNode const*) @ 0x0000000032d1e39e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexConditionBloomFilter.cpp:266: DB::MergeTreeIndexConditionBloomFilter::extractAtomFromTree(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&) @ 0x0000000032d1e0e0 22. ./src/Storages/MergeTree/RPNBuilder.h:242: DB::RPNBuilder::traverseTree(DB::RPNBuilderTreeNode const&) @ 0x0000000032d35e9b 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032d1c248 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeIndexConditionBloomFilter* std::construct_at[abi:v15000] const&, std::shared_ptr&, DB::Block const&, unsigned long const&, DB::MergeTreeIndexConditionBloomFilter*>(DB::MergeTreeIndexConditionBloomFilter*, std::shared_ptr const&, std::shared_ptr&, DB::Block const&, unsigned long const&) @ 0x0000000032d10ca7 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000] const&, std::shared_ptr&, DB::Block const&, unsigned long const&>(std::allocator, std::shared_ptr const&, std::shared_ptr&, DB::Block const&, unsigned long const&) @ 0x0000000032d1072a 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr const&, std::shared_ptr&, DB::Block const&, unsigned long const&, void>(std::allocator const&, std::shared_ptr const&, std::shared_ptr&, DB::Block const&, unsigned long const&) @ 0x0000000032d104d2 27. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:48: DB::MergeTreeIndexBloomFilter::createIndexCondition(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032d0e78e 28. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildIndexes(std::optional&, std::shared_ptr, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) @ 0x0000000033f3e75a 29. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1546: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x0000000033f3d429 30. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000003400c97b 31. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyCondition.cpp:41: DB::QueryPlanOptimizations::optimizePrimaryKeyCondition(std::vector> const&) @ 0x000000003400c5e1 2025.03.05 21:09:29.585378 [ 14973 ] {e61ac1dc-cc12-4c13-aed6-631dda2c131c} executeQuery: Code: 36. DB::Exception: Primary key cannot be updated (cannot update column key). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:56756) (comment: 02707_keeper_map_delete_update_strict.sql) (in query: ALTER TABLE 02707_keepermap_delete_update UPDATE key = key * 10 WHERE 1 = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/StorageKeeperMap.cpp:1231: DB::StorageKeeperMap::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000322bf500 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:29.585578 [ 14973 ] {e61ac1dc-cc12-4c13-aed6-631dda2c131c} TCPHandler: Code: 36. DB::Exception: Primary key cannot be updated (cannot update column key). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/StorageKeeperMap.cpp:1231: DB::StorageKeeperMap::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000322bf500 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:30.590045 [ 14920 ] {f4bbf012-d026-4a35-896d-dc90ba44b9f5} executeQuery: Code: 999. Coordination::Exception: Transaction failed (Node exists): Op #0, path: /test_keeper_map/test_1sy04esq/test_02706_keeper_map_insert_strict/data/AQAAAAAAAAA=. (KEEPER_EXCEPTION) (version 24.3.12.76.altinitystable) (from [::1]:56790) (comment: 02706_keeper_map_insert_strict.sql) (in query: INSERT INTO 02706_keeper_map_insert_strict VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x00000000343acd8a 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003438c384 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1444: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003437e83d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:693: zkutil::ZooKeeper::multi(std::vector, std::allocator>> const&, bool) @ 0x000000003437e79e 7. ./contrib/llvm-project/libcxx/include/vector:580: void DB::StorageKeeperMapSink::finalize(bool) @ 0x00000000322d55e1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51db1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 12. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:30.590248 [ 14920 ] {f4bbf012-d026-4a35-896d-dc90ba44b9f5} TCPHandler: Code: 999. Coordination::Exception: Transaction failed (Node exists): Op #0, path: /test_keeper_map/test_1sy04esq/test_02706_keeper_map_insert_strict/data/AQAAAAAAAAA=. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, Coordination::Error&, unsigned long&) @ 0x00000000343acd8a 4. ./src/Common/ZooKeeper/IKeeper.h:490: zkutil::KeeperMultiException::KeeperMultiException(Coordination::Error, unsigned long, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003438c384 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1444: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003437e83d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:693: zkutil::ZooKeeper::multi(std::vector, std::allocator>> const&, bool) @ 0x000000003437e79e 7. ./contrib/llvm-project/libcxx/include/vector:580: void DB::StorageKeeperMapSink::finalize(bool) @ 0x00000000322d55e1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51db1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 12. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:30.858948 [ 14920 ] {012414e4-9061-4b8a-af25-c14c1c0b1f4c} executeQuery: Code: 43. DB::Exception: First argument for this overload of arrayMap must be a function with 1 arguments, found Function((?, ?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:56792) (comment: 02706_array_map_tuples.sql) (in query: WITH [(1, 2)] AS arr1 SELECT arrayMap((x, y, z) -> (y, x, z), arr1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000018082175 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000021ec1d92 5. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ae00b 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:30.859186 [ 14920 ] {012414e4-9061-4b8a-af25-c14c1c0b1f4c} TCPHandler: Code: 43. DB::Exception: First argument for this overload of arrayMap must be a function with 1 arguments, found Function((?, ?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000018082175 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000021ec1d92 5. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ae00b 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:30.861667 [ 14920 ] {d046ca64-0acd-4c60-a2ee-de47aa66bfab} executeQuery: Code: 43. DB::Exception: First argument for this overload of arrayMap must be a function with 1 arguments, found Function((?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:56792) (comment: 02706_array_map_tuples.sql) (in query: WITH [1, 2] AS arr1 SELECT arrayMap((x, y) -> (y, x), arr1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000018082175 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000021ec1d92 5. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ae00b 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:30.861770 [ 14920 ] {d046ca64-0acd-4c60-a2ee-de47aa66bfab} TCPHandler: Code: 43. DB::Exception: First argument for this overload of arrayMap must be a function with 1 arguments, found Function((?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000018082175 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000021ec1d92 5. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ae00b 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:31.517889 [ 14920 ] {03fed589-de06-496b-99c3-21ba29829271} executeQuery: Code: 48. DB::Exception: EXPLAIN QUERY TREE is only supported with a new analyzer. Set allow_experimental_analyzer = 1. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:56798) (comment: 02703_explain_query_tree_is_forbidden_with_old_analyzer.sql) (in query: EXPLAIN QUERY TREE run_passes = true, dump_passes = true SELECT 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::executeImpl() @ 0x00000000308044b1 5. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x00000000307fd3c4 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:31.518127 [ 14920 ] {03fed589-de06-496b-99c3-21ba29829271} TCPHandler: Code: 48. DB::Exception: EXPLAIN QUERY TREE is only supported with a new analyzer. Set allow_experimental_analyzer = 1. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::executeImpl() @ 0x00000000308044b1 5. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x00000000307fd3c4 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:32.864595 [ 14974 ] {e509402e-15b9-4832-8635-de4ad3ef398e} executeQuery: Code: 309. DB::Exception: Function toUInt64 is not parametric. (FUNCTION_CANNOT_HAVE_PARAMETERS) (version 24.3.12.76.altinitystable) (from [::1]:56854) (comment: 02701_non_parametric_function.sql) (in query: SELECT * FROM system.numbers WHERE number > toUInt64(10)(number) LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b6a7c 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:32.864875 [ 14974 ] {e509402e-15b9-4832-8635-de4ad3ef398e} TCPHandler: Code: 309. DB::Exception: Function toUInt64 is not parametric. (FUNCTION_CANNOT_HAVE_PARAMETERS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b6a7c 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:33.652260 [ 1658 ] {dc1b49aa-c02d-44f7-a255-86c091b90c63} executeQuery: Code: 473. DB::Exception: StorageJoin: cannot insert data because current query tries to read from this storage. (DEADLOCK_AVOIDED) (version 24.3.12.76.altinitystable) (from [::1]:56950) (comment: 02695_storage_join_insert_select_deadlock.sql) (in query: INSERT INTO test_table_join SELECT * from test_table_join;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageJoin.cpp:263: DB::StorageJoin::insertBlock(DB::Block const&, std::shared_ptr) @ 0x000000003224a8de 5. ./build_docker/./src/Storages/StorageSet.cpp:90: DB::SetOrJoinSink::consume(DB::Chunk) @ 0x00000000325ff2d0 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 13. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 14. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 15. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:33.652793 [ 1658 ] {dc1b49aa-c02d-44f7-a255-86c091b90c63} TCPHandler: Code: 473. DB::Exception: StorageJoin: cannot insert data because current query tries to read from this storage. (DEADLOCK_AVOIDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageJoin.cpp:263: DB::StorageJoin::insertBlock(DB::Block const&, std::shared_ptr) @ 0x000000003224a8de 5. ./build_docker/./src/Storages/StorageSet.cpp:90: DB::SetOrJoinSink::consume(DB::Chunk) @ 0x00000000325ff2d0 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 13. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 14. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 15. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:33.660620 [ 1658 ] {b90bbd7b-2a35-4508-a4d4-1437523bfedc} executeQuery: Code: 473. DB::Exception: StorageJoin: cannot insert data because current query tries to read from this storage. (DEADLOCK_AVOIDED) (version 24.3.12.76.altinitystable) (from [::1]:56950) (comment: 02695_storage_join_insert_select_deadlock.sql) (in query: INSERT INTO test_table_join SELECT * FROM (SELECT 1 as id) AS t1 ANY LEFT JOIN test_table_join USING (id);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageJoin.cpp:263: DB::StorageJoin::insertBlock(DB::Block const&, std::shared_ptr) @ 0x000000003224a8de 5. ./build_docker/./src/Storages/StorageSet.cpp:90: DB::SetOrJoinSink::consume(DB::Chunk) @ 0x00000000325ff2d0 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 13. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 14. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 15. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:33.661008 [ 1658 ] {b90bbd7b-2a35-4508-a4d4-1437523bfedc} TCPHandler: Code: 473. DB::Exception: StorageJoin: cannot insert data because current query tries to read from this storage. (DEADLOCK_AVOIDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageJoin.cpp:263: DB::StorageJoin::insertBlock(DB::Block const&, std::shared_ptr) @ 0x000000003224a8de 5. ./build_docker/./src/Storages/StorageSet.cpp:90: DB::SetOrJoinSink::consume(DB::Chunk) @ 0x00000000325ff2d0 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 13. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 14. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 15. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:33.668553 [ 1658 ] {401b51d1-e692-41ac-8205-46c3a9f65490} executeQuery: Code: 473. DB::Exception: StorageJoin: cannot insert data because current query tries to read from this storage. (DEADLOCK_AVOIDED) (version 24.3.12.76.altinitystable) (from [::1]:56950) (comment: 02695_storage_join_insert_select_deadlock.sql) (in query: INSERT INTO test_table_join SELECT id, toString(id) FROM (SELECT 1 as id) AS t1 ANY LEFT JOIN (SELECT id FROM test_table_join) AS t2 USING (id);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageJoin.cpp:263: DB::StorageJoin::insertBlock(DB::Block const&, std::shared_ptr) @ 0x000000003224a8de 5. ./build_docker/./src/Storages/StorageSet.cpp:90: DB::SetOrJoinSink::consume(DB::Chunk) @ 0x00000000325ff2d0 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 13. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 14. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 15. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:33.669139 [ 1658 ] {401b51d1-e692-41ac-8205-46c3a9f65490} TCPHandler: Code: 473. DB::Exception: StorageJoin: cannot insert data because current query tries to read from this storage. (DEADLOCK_AVOIDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageJoin.cpp:263: DB::StorageJoin::insertBlock(DB::Block const&, std::shared_ptr) @ 0x000000003224a8de 5. ./build_docker/./src/Storages/StorageSet.cpp:90: DB::SetOrJoinSink::consume(DB::Chunk) @ 0x00000000325ff2d0 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 13. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 14. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 15. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:33.915289 [ 1658 ] {04b3c683-85cd-471f-abbc-f1774513f136} executeQuery: Code: 47. DB::Exception: Identifier 't1.d' cannot be resolved from table with name test_58vslioo.t1. In scope SELECT * FROM t1 INNER JOIN s ON t1.k = s.k INNER JOIN t2 ON t2.x = t1.x WHERE t1.d >= now(). Maybe you meant: ['t1.k']. (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:56974) (comment: 02694_wrong_identifier_shouldnt_be_accepted.sql) (in query: SELECT * FROM t1 INNER JOIN s ON t1.k = s.k INNER JOIN t2 ON t2.x = t1.x WHERE (t1.d >= now());), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000003091f2a1 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::(anonymous namespace)::TableExpressionData const&, DB::(anonymous namespace)::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000308d6d5b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7872 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3436: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c8ff0 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3436: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c8ff0 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:33.915503 [ 1658 ] {04b3c683-85cd-471f-abbc-f1774513f136} TCPHandler: Code: 47. DB::Exception: Identifier 't1.d' cannot be resolved from table with name test_58vslioo.t1. In scope SELECT * FROM t1 INNER JOIN s ON t1.k = s.k INNER JOIN t2 ON t2.x = t1.x WHERE t1.d >= now(). Maybe you meant: ['t1.k']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000003091f2a1 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::(anonymous namespace)::TableExpressionData const&, DB::(anonymous namespace)::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000308d6d5b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7872 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3436: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c8ff0 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3436: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c8ff0 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:34.329609 [ 10241 ] {214e6f03-4b81-4ccf-b416-c747460317de} executeQuery: Code: 378. DB::Exception: Data type Bool cannot have arguments: In scope SELECT CAST('0', 'Bool(Upyachka)'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:57068) (comment: 02689_meaningless_data_types.sql) (in query: SELECT 0::Bool(Upyachka);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:226: std::pair, std::unique_ptr>> std::__function::__policy_invoker, std::unique_ptr>> (std::shared_ptr const&)>::__call_impl, std::unique_ptr>> ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::CaseSensitiveness)::$_0, std::pair, std::unique_ptr>> (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f47ad22 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl, std::unique_ptr>> (std::shared_ptr const&)>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::CaseSensitiveness)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f47a8f5 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f47c958 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002f47b0f7 8. ./build_docker/./src/Functions/CastOverloadResolver.cpp:99: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d2351 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:34.329899 [ 10241 ] {214e6f03-4b81-4ccf-b416-c747460317de} TCPHandler: Code: 378. DB::Exception: Data type Bool cannot have arguments: In scope SELECT CAST('0', 'Bool(Upyachka)'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:226: std::pair, std::unique_ptr>> std::__function::__policy_invoker, std::unique_ptr>> (std::shared_ptr const&)>::__call_impl, std::unique_ptr>> ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::CaseSensitiveness)::$_0, std::pair, std::unique_ptr>> (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f47ad22 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl, std::unique_ptr>> (std::shared_ptr const&)>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::CaseSensitiveness)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f47a8f5 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f47c958 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002f47b0f7 8. ./build_docker/./src/Functions/CastOverloadResolver.cpp:99: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d2351 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:34.331953 [ 10241 ] {5eeecd2a-8867-4671-992e-d1f7f5bcaf61} executeQuery: Code: 378. DB::Exception: Data type Ring cannot have arguments: In scope SELECT CAST('[(1, 2), (3, 4)]', 'Ring(Upyachka)'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:57068) (comment: 02689_meaningless_data_types.sql) (in query: SELECT [(1, 2), (3, 4)]::Ring(Upyachka);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:226: std::pair, std::unique_ptr>> std::__function::__policy_invoker, std::unique_ptr>> (std::shared_ptr const&)>::__call_impl, std::unique_ptr>> ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::CaseSensitiveness)::$_0, std::pair, std::unique_ptr>> (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f47ad22 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl, std::unique_ptr>> (std::shared_ptr const&)>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::CaseSensitiveness)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f47a8f5 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f47c958 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002f47b0f7 8. ./build_docker/./src/Functions/CastOverloadResolver.cpp:99: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d2351 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:34.332082 [ 10241 ] {5eeecd2a-8867-4671-992e-d1f7f5bcaf61} TCPHandler: Code: 378. DB::Exception: Data type Ring cannot have arguments: In scope SELECT CAST('[(1, 2), (3, 4)]', 'Ring(Upyachka)'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:226: std::pair, std::unique_ptr>> std::__function::__policy_invoker, std::unique_ptr>> (std::shared_ptr const&)>::__call_impl, std::unique_ptr>> ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::CaseSensitiveness)::$_0, std::pair, std::unique_ptr>> (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f47ad22 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl, std::unique_ptr>> (std::shared_ptr const&)>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::CaseSensitiveness)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f47a8f5 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f47c958 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002f47b0f7 8. ./build_docker/./src/Functions/CastOverloadResolver.cpp:99: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d2351 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:34.356064 [ 10241 ] {98a62d79-d202-4164-a702-683059187586} executeQuery: Code: 378. DB::Exception: Data type IPv4 cannot have arguments: In scope SELECT CAST('1.1.1.1', 'IPv4(\'Hello, world!\')'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:57068) (comment: 02689_meaningless_data_types.sql) (in query: SELECT '1.1.1.1'::IPv4('Hello, world!');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:205: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::CaseSensitiveness)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f47a5e1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f47c958 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002f47b0f7 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:99: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d2351 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:09:34.356315 [ 10241 ] {98a62d79-d202-4164-a702-683059187586} TCPHandler: Code: 378. DB::Exception: Data type IPv4 cannot have arguments: In scope SELECT CAST('1.1.1.1', 'IPv4(\'Hello, world!\')'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:205: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::CaseSensitiveness)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f47a5e1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f47c958 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002f47b0f7 7. ./build_docker/./src/Functions/CastOverloadResolver.cpp:99: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d2351 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:09:34.407195 [ 11268 ] {3317c667-80eb-44b4-88fc-fea927fe05ca} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: SilverlightVersion2: (at row 1) . (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&) @ 0x0000000033693f3b 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:808: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003368e795 5. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 7. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 9. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:171: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x00000000338c085b 10. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:108: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x00000000338bd238 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:34.408044 [ 10241 ] {3317c667-80eb-44b4-88fc-fea927fe05ca} executeQuery: Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: SilverlightVersion2: (at row 1) : While executing ParallelParsingBlockInputFormat. (INCORRECT_DATA) (version 24.3.12.76.altinitystable) (from [::1]:57084) (comment: 02685_bson2.sql) (in query: -- It correctly throws exception about incorrect data: SELECT * FROM format('BSONEachRow', 'WatchID Int64, JavaEnable Int16, Title String, GoodEvent Int16, EventTime DateTime, EventDate Date, CounterID Int32, ClientIP Int32, RegionID Int32, UserID Int64, CounterClass Int16, OS Int16, UserAgent Int16, URL String, Referer String, IsRefresh Int16, RefererCategoryID Int16, RefererRegionID Int32, URLCategoryID Int16, URLRegionID Int32, ResolutionWidth Int16, ResolutionHeight Int16, ResolutionDepth Int16, FlashMajor Int16, FlashMinor Int16, FlashMinor2 String, NetMajor Int16, NetMinor Int16, UserAgentMajor Int16, UserAgentMinor String, CookieEnable Int16, JavascriptEnable Int16, IsMobile Int16, MobilePhone Int16, MobilePhoneModel String, Params String, IPNetworkID Int32, TraficSourceID Int16, SearchEngineID Int16, SearchPhrase String, AdvEngineID Int16, IsArtifical Int16, WindowClientWidth Int16, WindowClientHeight Int16, ClientTimeZone Int16, ClientEventTime DateTime, SilverlightVersion1 Int16, SilverlightVersion2 Int16, SilverlightVersion3 Int32, SilverlightVersion4 Int16, PageCharset String, CodeVersion Int32, IsLink Int16, IsDownload Int16, IsNotBounce Int16, FUniqID Int64, OriginalURL String, HID Int32, IsOldCounter Int16, IsEvent Int16, IsParameter Int16, DontCountHits Int16, WithHash Int16, HitColor String, LocalEventTime DateTime, Age Int16, Sex Int16, Income Int16, Interests Int16, Robotness Int16, RemoteIP Int32, WindowName Int32, OpenerName Int32, HistoryLength Int16, BrowserLanguage String, BrowserCountry String, SocialNetwork String, SocialAction String, HTTPError Int16, SendTiming Int32, DNSTiming Int32, ConnectTiming Int32, ResponseStartTiming Int32, ResponseEndTiming Int32, FetchTiming Int32, SocialSourceNetworkID Int16, SocialSourcePage String, ParamPrice Int64, ParamOrderID String, ParamCurrency String, ParamCurrencyID Int16, OpenstatServiceName String, OpenstatCampaignID String, OpenstatAdID String, OpenstatSourceID String, UTMSource String, UTMMedium String, UTMCampaign String, UTMContent String, UTMTerm String, FromTag String, HasGCLID Int16, RefererHash Int64, URLHash Int64, CLID Int32', $$^WatchIDc*5/ !p~JavaEnableTitleGoodEventEventTime7ðâQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion2SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime&·ãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID^WatchID úFÚÓ“2qJavaEnableTitleGoodEventEventTimen$äQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeǘãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID^WatchIDl!è–|¨@HJavaEnableTitleGoodEventEventTimeÃ)äQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime}žãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID^WatchID²Ç=ÐŒWJavaEnableTitleGoodEventEventTime8*äQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeÝžãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID‹WatchIDéòˆE&LyJavaEnableTitleGoodEventEventTimeJîâQEventDate>CounterIDClientIPº‹I`RegionID'UserIDq—íJd8CounterClassOSUserAgentURL-http://holodilnik.ru/russia/05jul2013&model=0RefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryID¬9URLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajor UserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkIDŒd9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqID%œlû©+kOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime'¡ãQAgeSexIncomeInterests¦:RobotnessRemoteIP9ê3NWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashŽ oâïòeCLID¦WatchID¹ãk=÷±pJavaEnableTitleGoodEventEventTimeÉ ãQEventDate>CounterIDClientIP®Æz·RegionIDGUserID ÎKs}¡ïCounterClassOSUserAgentURLHhttp://afisha.mail.ru/catalog/314/women.ru/ency=1&page3/?errovat-pinnikiRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryID0=URLRegionIDØResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqID:¤ìWëÂmOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeA¶ãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashý€ à#â\CLIDœWatchIDæ1þž oíCJavaEnableTitleGoodEventEventTimeµ0äQEventDate>CounterIDClientIPÉ^{]RegionIDÅUserID&n%Št"6CounterClassOS'UserAgentURL>http://bonprix.ru/index.ru/cinema/art/0 986 424 233 ÑезонRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionID±ResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID‰#(TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime¼£ãQAgeSexIncomeInterestsRobotnessRemoteIP…UWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashX-h³ýX CLID˜WatchID»-ÞC_JavaEnableTitleGoodEventEventTime83äQEventDate>CounterIDClientIPÉ^{]RegionIDÅUserID&n%Št"6CounterClassOS'UserAgentURL:http://bonprix.ru/index.ru/cinema/art/A00387,3797); ru)&bLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionID±ResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID‰#(TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime ¦ãQAgeSexIncomeInterestsRobotnessRemoteIP…UWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashvÀvÍÀ‰ÇCLIDWatchIDìÒŒ\JavaEnableTitleGoodEventEventTime× äQEventDate>CounterIDClientIPgURegionIDåUserIDƒs—yyçófCounterClassOS,UserAgentURL1http://tours/Ekategoriya%2F&sr=http://slovareniyeRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDØesRolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajor UserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¶œTraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeY’ãQAgeSexIncomeInterestsRobotnessRemoteIP€=kWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashh˜´9›DCLID^WatchIDÛ/E‚ÜJÛ{JavaEnableTitleGoodEventEventTimeÖ1ãQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime‹ÏãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID$$);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&) @ 0x0000000033693f3b 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:808: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003368e795 5. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 7. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 9. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:171: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x00000000338c085b 10. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:108: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x00000000338bd238 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:34.408248 [ 10241 ] {3317c667-80eb-44b4-88fc-fea927fe05ca} TCPHandler: Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: SilverlightVersion2: (at row 1) : While executing ParallelParsingBlockInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&) @ 0x0000000033693f3b 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:808: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003368e795 5. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 7. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 9. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:171: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x00000000338c085b 10. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:108: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x00000000338bd238 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:34.618179 [ 1658 ] {0f1cee4c-e126-4678-8ea9-2dcef2adf2c0} executeQuery: Code: 131. DB::Exception: Too large string size: 18446744073709551615. The maximum is: 17179869184.: While executing Native. (TOO_LARGE_STRING_SIZE) (version 24.3.12.76.altinitystable) (from [::1]:57102) (comment: 02683_native_too_large_size.sql) (in query: SELECT * FROM format('Native', 'WatchID Int64, JavaEnable Int16, Title String, GoodEvent Int16, EventTime DateTime, EventDate Date, CounterID Int32, ClientIP Int32, RegionID Int32, UserID Int64, CounterClass Int16, OS Int16, UserAgent Int16, URL String, Referer String, IsRefresh Int16, RefererCategoryID Int16, RefererRegionID Int32, URLCategoryID Int16, URLRegionID Int32, ResolutionWidth Int16, ResolutionHeight Int16, ResolutionDepth Int16, FlashMajor Int16, FlashMinor Int16, FlashMinor2 String, NetMajor Int16, NetMinor Int16, UserAgentMajor Int16, UserAgentMinor String, CookieEnable Int16, JavascriptEnable Int16, IsMobile Int16, MobilePhone Int16, MobilePhoneModel String, Params String, IPNetworkID Int32, TraficSourceID Int16, SearchEngineID Int16, SearchPhrase String, AdvEngineID Int32, IsArtifical Int16, WindowClientWidth Int16, WindowClientHeight Int16, ClientTimeZone Int16, ClientEventTime DateTime, SilverlightVersion1 Int16, SilverlightVersion2 Int16, SilverlightVersion3 Int32, SilverlightVersion4 Int16, PageCharset String, CodeVersion Int32, IsLink Int16, IsDownload Int16, IsNotBounce Int16, FUniqID Int64, OriginalURL String, HID Int32, IsOldCounter Int16, IsEvent Int16, IsParameter Int16, DontCountHits Int16, WithHash Int16, HitColor String, LocalEventTime DateTime, Age Int16, Sex Int16, Income Int16, Interests Int16, Robotness Int16, RemoteIP Int32, VindowName Int32, OpenerName Int32, HistoryLength Int16, BrowserLanguage String, BrowserCountry String, SocialNetwork String, SocialAction String, HTTPError Int16, SendTiming Int32, DNSTiming Int32, ConnectTiming Int32, ResponseStartTiming Int32, ResponseEndTiming Int32, FetchTiming Int32, SocialSourceNetworkID Int16, SocialSourcePage String, ParamPrice Int64, ParamOrderID String, ParamCurrency String, ParamCurrencyID Int16, OpenstatServiceName String, OpenstatCampaignID String, OpenstatAdID String, OpenstatSourceID String, UTMSource String, UTMMedium String, UTMCampaign String, UTMContent String, UTMTerm String, FromTag String, HasGCLID Int16, RefererHash Int64, URLHash Int64, CLID Int32', $$i WatchIDInt64c*5/ !p~ úFÚÓ“2ql!è–|¨@H²Ç=ÐŒWéòˆE&Ly¹ãk=÷±pæ1þž oíC»-ÞC_ìÒŒ\Û/E‚ÜJÛ{ JavaEnableInt16TitleString GoodEventInt16 EventTimeDateTime7ðâQn$äQÃ)äQ8*äQJîâQÉ ãQµ0äQ83äQ× äQÖ1ãQ EventDateDate>>>>>>>>>> CounterIDInt32ClientIPInt32®Æz·®Æz·®Æz·®Æz·º‹I`®Æz·É^{]É^{]gU®Æz·RegionIDInt32GGGG'GÅÅåGUserIDInt64× ’•:6×Ý× ’•:6×Ý× ’•:6×Ý× ’•:6×Ýq—íJd8 ÎKs}¡ï&n%Št"6&n%Št"6ƒs—yyçóf× ’•:6×Ý CounterClassInt16OSInt16'', UserAgentInt16URLString-http://holodilInt16WindowClientWidthInt16WindowClientHeightInt16ClientTimeZoneInt16ÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿClientEventTimeDateTimeîáîáîáîáîáîáîáîáîáîáSilverlightVersion1Int16SilverlightVersion2Int16SilverlightVersion3Int32SilverlightVersion4Int16 PageCharsetString CodeVersionInt32IsLinkInt16 IsDownloadInt16 IsNotBounceInt16FUniqIDInt64%œlû©+k:¤ìWëÂm OriginalURLStringHIDInt32 IsOldCounterInt16IsEventInt16 IsParameterInt16 DontCountHitsInt16WithHashInt16HitColorString5555555555LocalEventTimeDateTime&·ãQǘãQ}žãQÝžãQ'¡ãQA¶ãQ¼£ãQ ¦ãQY’ãQ‹ÏãQAgeInt16SexInt16IncomeInt16 InterestsInt16¦: RobotnessInt16RemoteIPInt32^DIÄ^DIÄ^DIÄ^DIÄ9ê3N^DIÄ…U…U€=k^DIÄ WindowNameInt32ÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿ OpenerNameInt32ÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿ HistoryLengthInt16ÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿBrowserLanguageString����������BrowserCountryString� � � � � � � � � � SocialNetworkString SocialActionString HTTPErrorInt16 SendTimingInt32 DNSTimingInt32 ConnectTimingInt32ResponseStartTimingInt32ResponseEndTimingInt32 FetchTimingInt32SocialSourceNetworkIDInt16SocialSourcePageString ParamPriceInt64 ParamOrderIDString ParamCurrencyStringNHNHNHNHNHNHNHNHNHNHParamCurrencyIDInt16OpenstatServiceNameStringOpenstatCampaignIDString OpenstatAdIDStringOpenstatSourceIDString UTMSourceString UTMMediumString UTMCampaignString UTMContentStringUTMTermStringFromTagStringHasGCLIDInt16 RefererHashInt64X+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûURLHashInt64Í|3úÐb.‹Í|3úÐb.‹Í|3úÐb.‹Í|3úÐb.‹Ž oâïòeý€ à#â\X-h³ýX vÀvÍÀ‰Çh˜´9›DÍ|3úÐb.‹CLIDInt32$$);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:168: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f6949e1 5. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:142: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5a438d 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::NativeReader::readData(DB::ISerialization const&, COW::immutable_ptr&, DB::ReadBuffer&, unsigned long, double) @ 0x0000000033505f67 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::NativeReader::read() @ 0x00000000335073b8 8. ./build_docker/./src/Processors/Formats/Impl/NativeFormat.cpp:43: DB::NativeInputFormat::read() @ 0x0000000033848a75 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 10. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 14. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 19. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 28. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 30. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 2025.03.05 21:09:34.618436 [ 1658 ] {0f1cee4c-e126-4678-8ea9-2dcef2adf2c0} TCPHandler: Code: 131. DB::Exception: Too large string size: 18446744073709551615. The maximum is: 17179869184.: While executing Native. (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:168: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f6949e1 5. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:142: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5a438d 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::NativeReader::readData(DB::ISerialization const&, COW::immutable_ptr&, DB::ReadBuffer&, unsigned long, double) @ 0x0000000033505f67 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::NativeReader::read() @ 0x00000000335073b8 8. ./build_docker/./src/Processors/Formats/Impl/NativeFormat.cpp:43: DB::NativeInputFormat::read() @ 0x0000000033848a75 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 10. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 14. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 19. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 28. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 30. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 2025.03.05 21:09:34.844434 [ 3522 ] {eb1d914a-077a-4f8e-8e49-4c5ac0759ed6} executeQuery: Code: 128. DB::Exception: Too large array size (maximum: 1073741824): While executing BinaryRowInputFormat. (TOO_LARGE_ARRAY_SIZE) (version 24.3.12.76.altinitystable) (from [::1]:57138) (comment: 02682_quantiles_too_large_size.sql) (in query: -- This query throw high-level exception instead of low-level "too large size passed to allocator": SELECT * FROM format(RowBinary, 'ik2 String, Sum AggregateFunction(sum, UInt16), A$g AggregateFunction(quantiles(0.4, 0.9), UInt64), GroupArray AggregateFunction(groupArray, String)', '295TMi44400000005942762421546108502 ö z *  ParalcelParsingInputFormat   te Date, I ! STRING  d Tuple(UInt8) vvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvTabSeparatedWithNamesAndTypes d Date, a S)ring, x UInt32, y UInt64, z Float32 29TabSeparatevvvvvvvdRawWithNames a UInt32 26TabSeparatedR,éb UInt32 26TabSeparatedRawWithNthNames vvvvv 1 key U7878 ');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x00000000192fbcfb 4. ./src/AggregateFunctions/ReservoirSampler.h:216: ReservoirSampler>::read(DB::ReadBuffer&) @ 0x0000000025c1931d 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:57: DB::SerializationAggregateFunction::deserializeBinary(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5adc6c 6. ./build_docker/./src/Processors/Formats/Impl/BinaryRowInputFormat.cpp:78: DB::BinaryFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000336af448 7. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 10. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 14. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 19. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 28. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 30. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 2025.03.05 21:09:34.844716 [ 3522 ] {eb1d914a-077a-4f8e-8e49-4c5ac0759ed6} TCPHandler: Code: 128. DB::Exception: Too large array size (maximum: 1073741824): While executing BinaryRowInputFormat. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x00000000192fbcfb 4. ./src/AggregateFunctions/ReservoirSampler.h:216: ReservoirSampler>::read(DB::ReadBuffer&) @ 0x0000000025c1931d 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:57: DB::SerializationAggregateFunction::deserializeBinary(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5adc6c 6. ./build_docker/./src/Processors/Formats/Impl/BinaryRowInputFormat.cpp:78: DB::BinaryFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000336af448 7. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 10. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 14. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 19. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 28. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 30. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 2025.03.05 21:09:35.014245 [ 3522 ] {064c5300-4648-48f5-bb9a-d4692b701b9a} executeQuery: Code: 57. DB::Exception: Table `test_q318cn11`.`02681_undrop_detach` already exists (detached). (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:57148) (comment: 02681_undrop_query.sql) (in query: undrop table 02681_undrop_detach;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x000000002f72486c 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x000000002f724428 6. ./build_docker/./src/Interpreters/InterpreterUndropQuery.cpp:0: DB::InterpreterUndropQuery::executeToTable(DB::ASTUndropQuery&) @ 0x0000000031778ba9 7. ./build_docker/./src/Interpreters/InterpreterUndropQuery.cpp:0: DB::InterpreterUndropQuery::execute() @ 0x0000000031778084 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:35.014457 [ 3522 ] {064c5300-4648-48f5-bb9a-d4692b701b9a} TCPHandler: Code: 57. DB::Exception: Table `test_q318cn11`.`02681_undrop_detach` already exists (detached). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x000000002f72486c 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x000000002f724428 6. ./build_docker/./src/Interpreters/InterpreterUndropQuery.cpp:0: DB::InterpreterUndropQuery::executeToTable(DB::ASTUndropQuery&) @ 0x0000000031778ba9 7. ./build_docker/./src/Interpreters/InterpreterUndropQuery.cpp:0: DB::InterpreterUndropQuery::execute() @ 0x0000000031778084 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:35.054669 [ 1901 ] {8de3e6c3-ceeb-4f79-b1d3-b2572cf93799} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 128. DB::Exception: Too large array element size 18446744073709551615 (maximum: 16777215). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018820822 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:400: DB::(anonymous namespace)::GroupArrayNodeBase::checkElementSize(unsigned long, unsigned long) @ 0x000000002574d976 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:419: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002574da68 6. ./src/Common/PODArray.h:312: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000257a2bbc 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b0f42 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 14. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:171: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x00000000338c085b 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:108: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x00000000338bd238 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:35.055573 [ 730 ] {8de3e6c3-ceeb-4f79-b1d3-b2572cf93799} executeQuery: Code: 128. DB::Exception: Too large array element size 18446744073709551615 (maximum: 16777215): While executing ParallelParsingBlockInputFormat. (TOO_LARGE_ARRAY_SIZE) (version 24.3.12.76.altinitystable) (from [::1]:57172) (comment: 02681_group_array_too_large_size.sql) (in query: -- This query throw high-level exception instead of low-level "too large size passed to allocator": SELECT * FROM format(CSV, 'entitypArray AggregateFunction(groupArray, String)', '295TMiews.viewNÿÿÿÿÿ""""""TabSeparÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿated d St"" r');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018820822 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:400: DB::(anonymous namespace)::GroupArrayNodeBase::checkElementSize(unsigned long, unsigned long) @ 0x000000002574d976 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:419: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002574da68 6. ./src/Common/PODArray.h:312: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000257a2bbc 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b0f42 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 14. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:171: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x00000000338c085b 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:108: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x00000000338bd238 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:35.055804 [ 730 ] {8de3e6c3-ceeb-4f79-b1d3-b2572cf93799} TCPHandler: Code: 128. DB::Exception: Too large array element size 18446744073709551615 (maximum: 16777215): While executing ParallelParsingBlockInputFormat. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018820822 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:400: DB::(anonymous namespace)::GroupArrayNodeBase::checkElementSize(unsigned long, unsigned long) @ 0x000000002574d976 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:419: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002574da68 6. ./src/Common/PODArray.h:312: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000257a2bbc 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b0f42 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:783: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f634499 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003371aa05 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9cfc 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 14. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:171: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x00000000338c085b 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:108: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x00000000338bd238 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:35.302103 [ 730 ] {7640c029-d16f-4be1-8104-5d2e3858915d} executeQuery: Code: 46. DB::Exception: Table function 'mysql' cannot be used as an expression: While processing mysql('127.0.0.1:9004', _CAST('test_ycpffdtb', 'String'), 'foo', 'default', '[HIDDEN]'). (UNKNOWN_FUNCTION) (version 24.3.12.76.altinitystable) (from [::1]:57184) (comment: 02680_mysql_ast_logical_err.sql) (in query: SELECT count() FROM mysql(mysql('127.0.0.1:9004', currentDatabase(), 'foo', 'default', '[HIDDEN]'), '127.0.0.1:9004', currentDatabase(), 'foo', '[HIDDEN]', '')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Parsers/ASTFunction.cpp:44: DB::ASTFunction::appendColumnNameImpl(DB::WriteBuffer&) const @ 0x00000000344e5b0a 5. ./build_docker/./src/Parsers/IAST.cpp:198: DB::IAST::getColumnName() const @ 0x00000000346230d4 6. ./contrib/llvm-project/libcxx/include/vector:571: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe306a6 7. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002fe1eecd 8. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, std::shared_ptr&, bool) @ 0x000000002fddf8d7 9. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1795: DB::ExpressionAnalyzer::getConstActionsDAG(std::vector> const&) @ 0x000000002fdf7c1b 10. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:87: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x00000000316be45f 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316bf2e4 12. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:0: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316bf55b 13. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:148: DB::evaluateConstantExpressionOrIdentifierAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316bf7c5 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageMySQL::getConfiguration(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, DB::MySQLSettings&) @ 0x00000000323655f5 15. ./build_docker/./src/TableFunctions/TableFunctionMySQL.cpp:0: DB::(anonymous namespace)::TableFunctionMySQL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4e1205 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:35.302409 [ 730 ] {7640c029-d16f-4be1-8104-5d2e3858915d} TCPHandler: Code: 46. DB::Exception: Table function 'mysql' cannot be used as an expression: While processing mysql('127.0.0.1:9004', _CAST('test_ycpffdtb', 'String'), 'foo', 'default', '[HIDDEN]'). (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Parsers/ASTFunction.cpp:44: DB::ASTFunction::appendColumnNameImpl(DB::WriteBuffer&) const @ 0x00000000344e5b0a 5. ./build_docker/./src/Parsers/IAST.cpp:198: DB::IAST::getColumnName() const @ 0x00000000346230d4 6. ./contrib/llvm-project/libcxx/include/vector:571: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe306a6 7. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002fe1eecd 8. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, std::shared_ptr&, bool) @ 0x000000002fddf8d7 9. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1795: DB::ExpressionAnalyzer::getConstActionsDAG(std::vector> const&) @ 0x000000002fdf7c1b 10. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:87: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x00000000316be45f 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316bf2e4 12. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:0: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316bf55b 13. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:148: DB::evaluateConstantExpressionOrIdentifierAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316bf7c5 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageMySQL::getConfiguration(absl::InlinedVector, 7ul, std::allocator>>, std::shared_ptr, DB::MySQLSettings&) @ 0x00000000323655f5 15. ./build_docker/./src/TableFunctions/TableFunctionMySQL.cpp:0: DB::(anonymous namespace)::TableFunctionMySQL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4e1205 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:35.324052 [ 730 ] {d9e023b4-0355-4a40-be9e-275f803521a2} executeQuery: Code: 1. DB::Exception: Invalid expression. Expected identifier, literal, matcher, function, subquery. Actual connection_pool_size = 1. (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:57184) (comment: 02680_mysql_ast_logical_err.sql) (in query: SELECT count() FROM mysql(mysql('127.0.0.1:9004', currentDatabase(), 'foo', 'default', '[HIDDEN]', SETTINGS connection_pool_size = 1), '127.0.0.1:9004', currentDatabase(), 'foo', '[HIDDEN]', '')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030817489 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:621: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030815587 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:849: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003082340e 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:35.324274 [ 730 ] {d9e023b4-0355-4a40-be9e-275f803521a2} TCPHandler: Code: 1. DB::Exception: Invalid expression. Expected identifier, literal, matcher, function, subquery. Actual connection_pool_size = 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030817489 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:621: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030815587 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:849: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003082340e 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:35.749637 [ 3522 ] {177388c8-8630-426b-997c-c7e64385c7d0} executeQuery: Code: 57. DB::Exception: Cannot undrop table, test_q318cn11.`02681_undrop_multiple` already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:57148) (comment: 02681_undrop_query.sql) (in query: undrop table 02681_undrop_multiple;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID&) @ 0x0000000031779283 4. ./build_docker/./src/Interpreters/InterpreterUndropQuery.cpp:0: DB::InterpreterUndropQuery::executeToTable(DB::ASTUndropQuery&) @ 0x0000000031778eeb 5. ./build_docker/./src/Interpreters/InterpreterUndropQuery.cpp:0: DB::InterpreterUndropQuery::execute() @ 0x0000000031778084 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:35.749786 [ 3522 ] {177388c8-8630-426b-997c-c7e64385c7d0} TCPHandler: Code: 57. DB::Exception: Cannot undrop table, test_q318cn11.`02681_undrop_multiple` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID&) @ 0x0000000031779283 4. ./build_docker/./src/Interpreters/InterpreterUndropQuery.cpp:0: DB::InterpreterUndropQuery::executeToTable(DB::ASTUndropQuery&) @ 0x0000000031778eeb 5. ./build_docker/./src/Interpreters/InterpreterUndropQuery.cpp:0: DB::InterpreterUndropQuery::execute() @ 0x0000000031778084 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:35.810401 [ 5753 ] {} Access(user directories): from: ::1, user: non_exist_user: Authentication failed: Code: 192. DB::Exception: There is no user `non_exist_user` in local_directory. (UNKNOWN_USER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x000000002edfc9e4 5. ./build_docker/./src/Access/IAccessStorage.cpp:546: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f00 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:35.810824 [ 5753 ] {} ServerErrorHandler: Code: 516. DB::Exception: non_exist_user: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:35.952574 [ 5753 ] {84337af5-1769-4c97-a2fb-c4ddd2dd7e70} executeQuery: Code: 43. DB::Exception: Comparing aggregate functions with different types: AggregateFunction(groupBitmap, UInt8) and AggregateFunction(groupBitmap, UInt64): While processing bitmapHasAny(bitmapBuild([toUInt8(1)]), __scalarSubqueryResult(_CAST('\0\0', 'AggregateFunction(groupBitmap, UInt8)')) AS _subquery11) AS has1, bitmapHasAny(bitmapBuild([toUInt64(1)]), __scalarSubqueryResult(_CAST('\0\0', 'AggregateFunction(groupBitmap, UInt64)')) AS _subquery12) AS has2. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:57240) (comment: 02677_analyzer_bitmap_has_any.sql) (in query: SELECT * FROM ( SELECT bitmapHasAny(bitmapBuild([toUInt8(1)]), ( SELECT groupBitmapState(toUInt8(1)) )) has1, bitmapHasAny(bitmapBuild([toUInt64(1)]), ( SELECT groupBitmapState(toUInt64(2)) )) has2 ) SETTINGS allow_experimental_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. DB::AggregateFunctionStateData::operator==(DB::AggregateFunctionStateData const&) const @ 0x00000000199cea57 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTLiteral const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe3c06c 6. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1230: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe359b0 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1230: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe359b0 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1230: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe359b0 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe3ce75 10. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002fe1eecd 11. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, std::shared_ptr&, bool) @ 0x000000002fddf8d7 12. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000002fdf2a6d 13. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2071: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000002fdfa383 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1059: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7e037 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f6287d 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 17. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 19. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bd9a3 21. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:287: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x00000000310c2f38 22. ./build_docker/./src/Interpreters/getTableExpressions.cpp:91: DB::getDatabaseAndTablesWithColumns(std::vector> const&, std::shared_ptr, bool, bool, bool) @ 0x0000000031727869 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::JoinedTables::resolveTables() @ 0x00000000310feaf6 24. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:478: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f50119 25. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 27. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:09:35.952590 [ 10241 ] {} Access(user directories): from: ::1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:35.952829 [ 5753 ] {84337af5-1769-4c97-a2fb-c4ddd2dd7e70} TCPHandler: Code: 43. DB::Exception: Comparing aggregate functions with different types: AggregateFunction(groupBitmap, UInt8) and AggregateFunction(groupBitmap, UInt64): While processing bitmapHasAny(bitmapBuild([toUInt8(1)]), __scalarSubqueryResult(_CAST('\0\0', 'AggregateFunction(groupBitmap, UInt8)')) AS _subquery11) AS has1, bitmapHasAny(bitmapBuild([toUInt64(1)]), __scalarSubqueryResult(_CAST('\0\0', 'AggregateFunction(groupBitmap, UInt64)')) AS _subquery12) AS has2. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. DB::AggregateFunctionStateData::operator==(DB::AggregateFunctionStateData const&) const @ 0x00000000199cea57 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTLiteral const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe3c06c 6. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1230: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe359b0 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1230: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe359b0 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1230: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe359b0 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe3ce75 10. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002fe1eecd 11. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, std::shared_ptr&, bool) @ 0x000000002fddf8d7 12. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x000000002fdf2a6d 13. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2071: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000002fdfa383 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1059: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7e037 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f6287d 16. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 17. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 19. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bd9a3 21. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:287: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x00000000310c2f38 22. ./build_docker/./src/Interpreters/getTableExpressions.cpp:91: DB::getDatabaseAndTablesWithColumns(std::vector> const&, std::shared_ptr, bool, bool, bool) @ 0x0000000031727869 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::JoinedTables::resolveTables() @ 0x00000000310feaf6 24. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:478: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f50119 25. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 27. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:09:35.952950 [ 10241 ] {} ServerErrorHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:36.244342 [ 10241 ] {bf2abc9b-d131-4c4c-854d-efde95cf893b} executeQuery: Code: 28. DB::Exception: Too high precision requested for Float, must not be more than 60, got 61: In scope SELECT toDecimalString(CAST('32.32', 'Float32'), 61). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER) (version 24.3.12.76.altinitystable) (from [::1]:57294) (comment: 02676_to_decimal_string.sql) (in query: -- Max number of decimal fractional digits is defined as 77 for Int/UInt/Decimal and 60 for Float. -- These values shall work OK. SELECT toDecimalString('32.32'::Float32, 61);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<_BitInt(8)>(int, FormatStringHelperImpl::type>, std::type_identity<_BitInt(8)>&&) @ 0x0000000021a36b63 4. void DB::(anonymous namespace)::FunctionToDecimalString::format(float, DB::WriteBuffer&, char8_t) @ 0x0000000021a3669d 5. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021a2763a 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:36.244588 [ 10241 ] {bf2abc9b-d131-4c4c-854d-efde95cf893b} TCPHandler: Code: 28. DB::Exception: Too high precision requested for Float, must not be more than 60, got 61: In scope SELECT toDecimalString(CAST('32.32', 'Float32'), 61). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<_BitInt(8)>(int, FormatStringHelperImpl::type>, std::type_identity<_BitInt(8)>&&) @ 0x0000000021a36b63 4. void DB::(anonymous namespace)::FunctionToDecimalString::format(float, DB::WriteBuffer&, char8_t) @ 0x0000000021a3669d 5. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021a2763a 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:36.273407 [ 10241 ] {f52aba26-2bfa-43c9-b7cb-5e80e8328ef1} executeQuery: Code: 28. DB::Exception: Too high precision requested for Float, must not be more than 60, got 61: In scope SELECT toDecimalString(CAST('64.64', 'Float64'), 61). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER) (version 24.3.12.76.altinitystable) (from [::1]:57294) (comment: 02676_to_decimal_string.sql) (in query: SELECT toDecimalString('64.64'::Float64, 61);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<_BitInt(8)>(int, FormatStringHelperImpl::type>, std::type_identity<_BitInt(8)>&&) @ 0x0000000021a36b63 4. void DB::(anonymous namespace)::FunctionToDecimalString::format(double, DB::WriteBuffer&, char8_t) @ 0x0000000021a369c3 5. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021a2820e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:36.273651 [ 10241 ] {f52aba26-2bfa-43c9-b7cb-5e80e8328ef1} TCPHandler: Code: 28. DB::Exception: Too high precision requested for Float, must not be more than 60, got 61: In scope SELECT toDecimalString(CAST('64.64', 'Float64'), 61). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<_BitInt(8)>(int, FormatStringHelperImpl::type>, std::type_identity<_BitInt(8)>&&) @ 0x0000000021a36b63 4. void DB::(anonymous namespace)::FunctionToDecimalString::format(double, DB::WriteBuffer&, char8_t) @ 0x0000000021a369c3 5. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021a2820e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:36.302336 [ 10241 ] {349d1605-ca4b-45bd-9f15-5a02d6632131} executeQuery: Code: 28. DB::Exception: Too many fractional digits requested, shall not be more than 77: In scope SELECT toDecimalString(CAST('88', 'UInt8'), 78). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER) (version 24.3.12.76.altinitystable) (from [::1]:57294) (comment: 02676_to_decimal_string.sql) (in query: SELECT toDecimalString('88'::UInt8, 78);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x00000000192fbcfb 4. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021a2b804 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:36.302566 [ 10241 ] {349d1605-ca4b-45bd-9f15-5a02d6632131} TCPHandler: Code: 28. DB::Exception: Too many fractional digits requested, shall not be more than 77: In scope SELECT toDecimalString(CAST('88', 'UInt8'), 78). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x00000000192fbcfb 4. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021a2b804 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:36.330837 [ 10241 ] {6c70a6c6-e43c-4954-a8b3-b998d1abc86c} executeQuery: Code: 28. DB::Exception: Too many fractional digits requested, shall not be more than 77: In scope SELECT toDecimalString(CAST('646464', 'Int256'), 78). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER) (version 24.3.12.76.altinitystable) (from [::1]:57294) (comment: 02676_to_decimal_string.sql) (in query: SELECT toDecimalString('646464'::Int256, 78);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x00000000192fbcfb 4. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021a2bd78 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:36.331150 [ 10241 ] {6c70a6c6-e43c-4954-a8b3-b998d1abc86c} TCPHandler: Code: 28. DB::Exception: Too many fractional digits requested, shall not be more than 77: In scope SELECT toDecimalString(CAST('646464', 'Int256'), 78). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x00000000192fbcfb 4. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021a2bd78 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:36.359416 [ 10241 ] {146e7772-5e52-4aca-a428-50571c889c65} executeQuery: Code: 28. DB::Exception: Too many fractional digits requested for Decimal, must not be more than 77: In scope SELECT toDecimalString(CAST('-128.789323123321329854641231237893231233213298546', 'Decimal256(45)'), 78). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER) (version 24.3.12.76.altinitystable) (from [::1]:57294) (comment: 02676_to_decimal_string.sql) (in query: SELECT toDecimalString('-128.789323123321329854641231237893231233213298546'::Decimal256(45), 78);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x00000000192fbcfb 4. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021a2c1a9 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:36.359655 [ 10241 ] {146e7772-5e52-4aca-a428-50571c889c65} TCPHandler: Code: 28. DB::Exception: Too many fractional digits requested for Decimal, must not be more than 77: In scope SELECT toDecimalString(CAST('-128.789323123321329854641231237893231233213298546', 'Decimal256(45)'), 78). (CANNOT_PRINT_FLOAT_OR_DOUBLE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x00000000192fbcfb 4. DB::(anonymous namespace)::FunctionToDecimalString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021a2c1a9 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:36.384139 [ 10241 ] {d5d2e4a7-df29-4279-933e-1d40f15725c7} executeQuery: Code: 44. DB::Exception: Illegal type of argument #2 'precision' of function toDecimalString, expected const Integer, got UInt8: In scope SELECT toDecimalString(CAST('256.256', 'Decimal256(45)'), *). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:57294) (comment: 02676_to_decimal_string.sql) (in query: -- wrong types: #52407 and similar SELECT toDecimalString('256.256'::Decimal256(45), *);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionToDecimalString::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021a34601 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:36.384366 [ 10241 ] {d5d2e4a7-df29-4279-933e-1d40f15725c7} TCPHandler: Code: 44. DB::Exception: Illegal type of argument #2 'precision' of function toDecimalString, expected const Integer, got UInt8: In scope SELECT toDecimalString(CAST('256.256', 'Decimal256(45)'), *). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionToDecimalString::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021a34601 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:36.386327 [ 10241 ] {287a6e7d-793e-43b3-a5ab-798c152adba2} executeQuery: Code: 43. DB::Exception: Illegal type of argument #2 'precision' of function toDecimalString, expected const Integer, got String: In scope SELECT toDecimalString(CAST('128.128', 'Decimal128(30)'), 'str'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:57294) (comment: 02676_to_decimal_string.sql) (in query: SELECT toDecimalString('128.128'::Decimal128(30), 'str');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionToDecimalString::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021a34601 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:36.386433 [ 10241 ] {287a6e7d-793e-43b3-a5ab-798c152adba2} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #2 'precision' of function toDecimalString, expected const Integer, got String: In scope SELECT toDecimalString(CAST('128.128', 'Decimal128(30)'), 'str'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionToDecimalString::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021a34601 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:36.387784 [ 10241 ] {ebc63c11-1399-46d2-8c10-f13d695860c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 1, should be 2: In scope SELECT toDecimalString(CAST('64.64', 'Decimal64(10)')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:57294) (comment: 02676_to_decimal_string.sql) (in query: SELECT toDecimalString('64.64'::Decimal64(10));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:36.387903 [ 10241 ] {ebc63c11-1399-46d2-8c10-f13d695860c8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 1, should be 2: In scope SELECT toDecimalString(CAST('64.64', 'Decimal64(10)')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:36.389196 [ 10241 ] {7b50111f-e931-4e04-9dd4-f52f62971743} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString(CAST('64.64', 'Decimal64(10)'), 3, 3). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:57294) (comment: 02676_to_decimal_string.sql) (in query: SELECT toDecimalString('64.64'::Decimal64(10), 3, 3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:36.389293 [ 10241 ] {7b50111f-e931-4e04-9dd4-f52f62971743} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString(CAST('64.64', 'Decimal64(10)'), 3, 3). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:36.642426 [ 10241 ] {f8aa181a-2c0c-40c9-a6e0-3bcd26774b6f} executeQuery: Code: 80. DB::Exception: Secondary index 't_constant_index' cannot contain constants. (INCORRECT_QUERY) (version 24.3.12.76.altinitystable) (from [::1]:57358) (comment: 02670_constant_skip_index.sql) (in query: CREATE TABLE t_constant_index (`id` UInt64, INDEX t_constant_index 'foo' TYPE set(2) GRANULARITY 1) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 20711, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 207716099, compact_parts_max_granules_to_buffer = 125, compact_parts_merge_max_bytes_to_prefetch_part = 3503042, merge_max_block_size = 21766, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 3105662, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 93732, primary_key_compress_block_size = 38889), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:0: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000032cd084f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af08f7 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 10. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 12. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:36.642660 [ 10241 ] {f8aa181a-2c0c-40c9-a6e0-3bcd26774b6f} TCPHandler: Code: 80. DB::Exception: Secondary index 't_constant_index' cannot contain constants. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndices.cpp:0: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000032cd084f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af08f7 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 10. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 12. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:36.672078 [ 10241 ] {a9348d44-08df-4ca5-ac8c-4654f9f96b5f} executeQuery: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `rand()`: for secondary index 't_constant_index'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:57358) (comment: 02670_constant_skip_index.sql) (in query: CREATE TABLE t_constant_index (`id` UInt64, INDEX t_constant_index id + rand() TYPE set(2) GRANULARITY 1) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 20711, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 207716099, compact_parts_max_granules_to_buffer = 125, compact_parts_merge_max_bytes_to_prefetch_part = 3503042, merge_max_block_size = 21766, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 3105662, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 93732, primary_key_compress_block_size = 38889), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1325: DB::ActionsDAG::assertDeterministic() const @ 0x000000002fb70181 5. ./contrib/llvm-project/libcxx/include/vector:1429: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000032cd069c 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af08f7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 13. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:36.672306 [ 10241 ] {a9348d44-08df-4ca5-ac8c-4654f9f96b5f} TCPHandler: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `rand()`: for secondary index 't_constant_index'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1325: DB::ActionsDAG::assertDeterministic() const @ 0x000000002fb70181 5. ./contrib/llvm-project/libcxx/include/vector:1429: DB::MergeTreeIndexFactory::validate(DB::IndexDescription const&, bool) const @ 0x0000000032cd069c 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af08f7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 13. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:36.742849 [ 5753 ] {f93bb8da-3126-47d8-824d-bc9dccaf5b20} executeQuery: Code: 41. DB::Exception: Value 0 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('00', '%m'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('00', '%m');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setMonth(int) @ 0x0000000020872f25 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMonth(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086ec8d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:36.743063 [ 5753 ] {f93bb8da-3126-47d8-824d-bc9dccaf5b20} TCPHandler: Code: 41. DB::Exception: Value 0 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('00', '%m'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setMonth(int) @ 0x0000000020872f25 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMonth(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086ec8d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:36.745371 [ 5753 ] {767d7e90-9d1b-4ca1-9dae-85898111f321} executeQuery: Code: 41. DB::Exception: Value 13 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('13', '%m'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('13', '%m');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setMonth(int) @ 0x0000000020872f25 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMonth(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086ec8d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:36.745481 [ 5753 ] {767d7e90-9d1b-4ca1-9dae-85898111f321} TCPHandler: Code: 41. DB::Exception: Value 13 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('13', '%m'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setMonth(int) @ 0x0000000020872f25 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMonth(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086ec8d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:36.774945 [ 5753 ] {6539b407-d76b-4cda-a298-f5c4ceeb01ef} executeQuery: Code: 41. DB::Exception: Invalid format input 12345 is malformed at 345: In scope SELECT parseDateTime('12345', '%m'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('12345', '%m');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:36.775182 [ 5753 ] {6539b407-d76b-4cda-a298-f5c4ceeb01ef} TCPHandler: Code: 41. DB::Exception: Invalid format input 12345 is malformed at 345: In scope SELECT parseDateTime('12345', '%m'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:36.813895 [ 5753 ] {f8681883-cb3f-4773-baba-d3c4a9a0a2d3} executeQuery: Code: 41. DB::Exception: Value 0 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('00', '%c'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('00', '%c');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setMonth(int) @ 0x0000000020872f25 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMonthWithoutLeadingZero(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086ea0d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:36.814133 [ 5753 ] {f8681883-cb3f-4773-baba-d3c4a9a0a2d3} TCPHandler: Code: 41. DB::Exception: Value 0 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('00', '%c'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setMonth(int) @ 0x0000000020872f25 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMonthWithoutLeadingZero(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086ea0d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:36.816798 [ 5753 ] {83b65fcd-a5ff-4f81-904e-5b9d105f37f0} executeQuery: Code: 41. DB::Exception: Value 13 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('13', '%c'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('13', '%c');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setMonth(int) @ 0x0000000020872f25 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMonthWithoutLeadingZero(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086ea0d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:36.816961 [ 5753 ] {83b65fcd-a5ff-4f81-904e-5b9d105f37f0} TCPHandler: Code: 41. DB::Exception: Value 13 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('13', '%c'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setMonth(int) @ 0x0000000020872f25 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMonthWithoutLeadingZero(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086ea0d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:36.818885 [ 5753 ] {57f85fcf-c6e3-4920-a052-04f77f3aaf21} executeQuery: Code: 41. DB::Exception: Invalid format input 12345 is malformed at 345: In scope SELECT parseDateTime('12345', '%c'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('12345', '%c');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:36.818987 [ 5753 ] {57f85fcf-c6e3-4920-a052-04f77f3aaf21} TCPHandler: Code: 41. DB::Exception: Invalid format input 12345 is malformed at 345: In scope SELECT parseDateTime('12345', '%c'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:36.854053 [ 5753 ] {35a58716-118e-4201-b494-6e81ab584f49} executeQuery: Code: 41. DB::Exception: Unable to parse fragment %b from abc because of unknown month of year short text abc: In scope SELECT parseDateTime('abc', '%b'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('abc', '%b');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, String&>(int, FormatStringHelperImpl::type, std::type_identity>>::type, std::type_identity::type>, String const&, std::basic_string_view>&&, String&) @ 0x00000000208a59f4 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMonthOfYearTextShort(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086e923 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:36.854295 [ 5753 ] {35a58716-118e-4201-b494-6e81ab584f49} TCPHandler: Code: 41. DB::Exception: Unable to parse fragment %b from abc because of unknown month of year short text abc: In scope SELECT parseDateTime('abc', '%b'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, String&>(int, FormatStringHelperImpl::type, std::type_identity>>::type, std::type_identity::type>, String const&, std::basic_string_view>&&, String&) @ 0x00000000208a59f4 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMonthOfYearTextShort(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086e923 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:36.895973 [ 5753 ] {46b891ac-528e-4ee2-83f8-1fc186b07deb} executeQuery: Code: 41. DB::Exception: Unable to parse first part of fragment %M from summer because of unknown month of year text: sum: In scope SELECT parseDateTime('summer', '%M'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('summer', '%M');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, String&>(int, FormatStringHelperImpl::type, std::type_identity>>::type, std::type_identity::type>, String const&, std::basic_string_view>&&, String&) @ 0x00000000208a59f4 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMonthOfYearTextLong(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x00000000208711f2 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:36.896148 [ 5753 ] {46b891ac-528e-4ee2-83f8-1fc186b07deb} TCPHandler: Code: 41. DB::Exception: Unable to parse first part of fragment %M from summer because of unknown month of year text: sum: In scope SELECT parseDateTime('summer', '%M'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, String&>(int, FormatStringHelperImpl::type, std::type_identity>>::type, std::type_identity::type>, String const&, std::basic_string_view>&&, String&) @ 0x00000000208a59f4 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMonthOfYearTextLong(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x00000000208711f2 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:36.945167 [ 5753 ] {0db95d54-2acb-43e7-b972-5b70eac7fe7f} executeQuery: Code: 41. DB::Exception: Value 60 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('60', '%M', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('60', '%M', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setMinute(int) @ 0x0000000020873c5d 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMinute(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002087164d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:36.945404 [ 5753 ] {0db95d54-2acb-43e7-b972-5b70eac7fe7f} TCPHandler: Code: 41. DB::Exception: Value 60 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('60', '%M', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setMinute(int) @ 0x0000000020873c5d 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMinute(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002087164d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:36.947846 [ 5753 ] {0e6a961a-0de7-498a-afd3-428d7ed0c983} executeQuery: Code: 41. DB::Exception: Value -29 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('-1', '%M', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('-1', '%M', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setMinute(int) @ 0x0000000020873c5d 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMinute(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002087164d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:36.947996 [ 5753 ] {0e6a961a-0de7-498a-afd3-428d7ed0c983} TCPHandler: Code: 41. DB::Exception: Value -29 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('-1', '%M', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setMinute(int) @ 0x0000000020873c5d 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMinute(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002087164d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:36.949948 [ 5753 ] {7897925c-88b8-4caa-9105-0bd98b3b1000} executeQuery: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%M', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('123456789', '%M', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:36.950128 [ 5753 ] {7897925c-88b8-4caa-9105-0bd98b3b1000} TCPHandler: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%M', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:36.990347 [ 5753 ] {10004675-5f7d-491d-aa06-aaa102e60f7e} executeQuery: Code: 41. DB::Exception: Value 0 for day of month must be in the range [1, 31]: In scope SELECT parseDateTime('00', '%d'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('00', '%d');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setDayOfMonth(int) @ 0x0000000020873445 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlDayOfMonth(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086ed0d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:36.990615 [ 5753 ] {10004675-5f7d-491d-aa06-aaa102e60f7e} TCPHandler: Code: 41. DB::Exception: Value 0 for day of month must be in the range [1, 31]: In scope SELECT parseDateTime('00', '%d'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setDayOfMonth(int) @ 0x0000000020873445 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlDayOfMonth(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086ed0d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:36.992829 [ 5753 ] {9f99c3b6-85da-40b1-8133-a929383ac7c1} executeQuery: Code: 41. DB::Exception: Value 32 for day of month must be in the range [1, 31]: In scope SELECT parseDateTime('32', '%d'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('32', '%d');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setDayOfMonth(int) @ 0x0000000020873445 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlDayOfMonth(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086ed0d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:36.992967 [ 5753 ] {9f99c3b6-85da-40b1-8133-a929383ac7c1} TCPHandler: Code: 41. DB::Exception: Value 32 for day of month must be in the range [1, 31]: In scope SELECT parseDateTime('32', '%d'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setDayOfMonth(int) @ 0x0000000020873445 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlDayOfMonth(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086ed0d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:36.995535 [ 5753 ] {1ca36496-6029-464a-816b-ab98096e574a} executeQuery: Code: 41. DB::Exception: Invalid format input 12345 is malformed at 345: In scope SELECT parseDateTime('12345', '%d'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('12345', '%d');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:36.995778 [ 5753 ] {1ca36496-6029-464a-816b-ab98096e574a} TCPHandler: Code: 41. DB::Exception: Invalid format input 12345 is malformed at 345: In scope SELECT parseDateTime('12345', '%d'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:37.036823 [ 5753 ] {2ed1adf8-a47b-44ff-9a78-7d5a03157860} executeQuery: Code: 41. DB::Exception: Invalid date, out of range (year: 2000 month: 2 day_of_month: 31): In scope SELECT parseDateTime('02-31', '%m-%d'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('02-31', '%m-%d');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&) @ 0x00000000208a7e27 4. DB::(anonymous namespace)::DateTime::daysSinceEpochFromDate(int, int, int) @ 0x0000000020874397 5. DB::(anonymous namespace)::DateTime::buildDateTime(DateLUTImpl const&) @ 0x000000002086b161 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002086937e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.037140 [ 5753 ] {2ed1adf8-a47b-44ff-9a78-7d5a03157860} TCPHandler: Code: 41. DB::Exception: Invalid date, out of range (year: 2000 month: 2 day_of_month: 31): In scope SELECT parseDateTime('02-31', '%m-%d'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&) @ 0x00000000208a7e27 4. DB::(anonymous namespace)::DateTime::daysSinceEpochFromDate(int, int, int) @ 0x0000000020874397 5. DB::(anonymous namespace)::DateTime::buildDateTime(DateLUTImpl const&) @ 0x000000002086b161 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002086937e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.040179 [ 5753 ] {d826c079-62ee-4e12-a5bb-63adc5e6ff52} executeQuery: Code: 41. DB::Exception: Invalid date, out of range (year: 2000 month: 4 day_of_month: 31): In scope SELECT parseDateTime('04-31', '%m-%d'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('04-31', '%m-%d');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&) @ 0x00000000208a7e27 4. DB::(anonymous namespace)::DateTime::daysSinceEpochFromDate(int, int, int) @ 0x0000000020874397 5. DB::(anonymous namespace)::DateTime::buildDateTime(DateLUTImpl const&) @ 0x000000002086b161 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002086937e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.040332 [ 5753 ] {d826c079-62ee-4e12-a5bb-63adc5e6ff52} TCPHandler: Code: 41. DB::Exception: Invalid date, out of range (year: 2000 month: 4 day_of_month: 31): In scope SELECT parseDateTime('04-31', '%m-%d'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&) @ 0x00000000208a7e27 4. DB::(anonymous namespace)::DateTime::daysSinceEpochFromDate(int, int, int) @ 0x0000000020874397 5. DB::(anonymous namespace)::DateTime::buildDateTime(DateLUTImpl const&) @ 0x000000002086b161 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002086937e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.056148 [ 5753 ] {b730004a-01a8-485d-bbec-9fbb3f14da6d} executeQuery: Code: 41. DB::Exception: Invalid date, out of range (year: 2001 month: 2 day_of_month: 29): In scope SELECT parseDateTime('2001-02-29', '%Y-%m-%d'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('2001-02-29', '%Y-%m-%d');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&) @ 0x00000000208a7e27 4. DB::(anonymous namespace)::DateTime::daysSinceEpochFromDate(int, int, int) @ 0x0000000020874397 5. DB::(anonymous namespace)::DateTime::buildDateTime(DateLUTImpl const&) @ 0x000000002086b161 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002086937e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.056365 [ 5753 ] {b730004a-01a8-485d-bbec-9fbb3f14da6d} TCPHandler: Code: 41. DB::Exception: Invalid date, out of range (year: 2001 month: 2 day_of_month: 29): In scope SELECT parseDateTime('2001-02-29', '%Y-%m-%d'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&) @ 0x00000000208a7e27 4. DB::(anonymous namespace)::DateTime::daysSinceEpochFromDate(int, int, int) @ 0x0000000020874397 5. DB::(anonymous namespace)::DateTime::buildDateTime(DateLUTImpl const&) @ 0x000000002086b161 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002086937e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.126595 [ 5753 ] {5eee979c-c0f6-4b63-ad7d-c1a436834b4c} executeQuery: Code: 41. DB::Exception: Invalid day of year, out of range (year: 1981 day of year: 366): In scope SELECT parseDateTime('1981 366', '%Y %j'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('1981 366', '%Y %j');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, int&, int&) @ 0x00000000208a7ba0 4. DB::(anonymous namespace)::DateTime::buildDateTime(DateLUTImpl const&) @ 0x000000002086b464 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002086937e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:37.126833 [ 5753 ] {5eee979c-c0f6-4b63-ad7d-c1a436834b4c} TCPHandler: Code: 41. DB::Exception: Invalid day of year, out of range (year: 1981 day of year: 366): In scope SELECT parseDateTime('1981 366', '%Y %j'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, int&, int&) @ 0x00000000208a7ba0 4. DB::(anonymous namespace)::DateTime::buildDateTime(DateLUTImpl const&) @ 0x000000002086b464 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002086937e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:37.163769 [ 5753 ] {93f0e974-c7f1-4a57-ba63-534165d43a4b} executeQuery: Code: 41. DB::Exception: Value 367 for day of year must be in the range [1, 366]: In scope SELECT parseDateTime('367', '%j'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('367', '%j');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setDayOfYear(int) @ 0x0000000020873a8b 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlDayOfYear(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086fefd 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.164044 [ 5753 ] {93f0e974-c7f1-4a57-ba63-534165d43a4b} TCPHandler: Code: 41. DB::Exception: Value 367 for day of year must be in the range [1, 366]: In scope SELECT parseDateTime('367', '%j'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setDayOfYear(int) @ 0x0000000020873a8b 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlDayOfYear(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086fefd 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.166597 [ 5753 ] {805f095c-1f0a-4a5a-adcf-40d94b4be13f} executeQuery: Code: 41. DB::Exception: Value 0 for day of year must be in the range [1, 366]: In scope SELECT parseDateTime('000', '%j'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('000', '%j');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setDayOfYear(int) @ 0x0000000020873a8b 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlDayOfYear(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086fefd 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.166711 [ 5753 ] {805f095c-1f0a-4a5a-adcf-40d94b4be13f} TCPHandler: Code: 41. DB::Exception: Value 0 for day of year must be in the range [1, 366]: In scope SELECT parseDateTime('000', '%j'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setDayOfYear(int) @ 0x0000000020873a8b 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlDayOfYear(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086fefd 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.168406 [ 5753 ] {fa0cd0d9-3d5d-4924-8358-43a3c4f446f3} executeQuery: Code: 41. DB::Exception: Invalid day of year, out of range (year: 2001 day of year: 366): In scope SELECT parseDateTime('2000 366 2001', '%Y %j %Y'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: -- The last one is chosen if multiple day of years are supplied. select parseDateTime('2000 366 2001', '%Y %j %Y');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, int&, int&) @ 0x00000000208a7ba0 4. DB::(anonymous namespace)::DateTime::buildDateTime(DateLUTImpl const&) @ 0x000000002086b464 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002086937e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:37.168538 [ 5753 ] {fa0cd0d9-3d5d-4924-8358-43a3c4f446f3} TCPHandler: Code: 41. DB::Exception: Invalid day of year, out of range (year: 2001 day of year: 366): In scope SELECT parseDateTime('2000 366 2001', '%Y %j %Y'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, int&, int&) @ 0x00000000208a7ba0 4. DB::(anonymous namespace)::DateTime::buildDateTime(DateLUTImpl const&) @ 0x000000002086b464 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002086937e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:09:37.210037 [ 5753 ] {4a3f1599-4c6e-461a-9bcf-8bb5707de344} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('24', '%H', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('24', '%H', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour24(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871e11 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.210276 [ 5753 ] {4a3f1599-4c6e-461a-9bcf-8bb5707de344} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('24', '%H', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour24(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871e11 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.212382 [ 5753 ] {63f6ac4d-c98d-45a3-be3b-b238d2a4072e} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('-1', '%H', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('-1', '%H', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour24(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871e11 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.212513 [ 5753 ] {63f6ac4d-c98d-45a3-be3b-b238d2a4072e} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('-1', '%H', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour24(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871e11 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.214191 [ 5753 ] {c600bc16-8754-4445-b258-27318a592e45} executeQuery: Code: 41. DB::Exception: Invalid format input 1234567 is malformed at 34567: In scope SELECT parseDateTime('1234567', '%H', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('1234567', '%H', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:37.214306 [ 5753 ] {c600bc16-8754-4445-b258-27318a592e45} TCPHandler: Code: 41. DB::Exception: Invalid format input 1234567 is malformed at 34567: In scope SELECT parseDateTime('1234567', '%H', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:37.263775 [ 5753 ] {28ef3b83-dd63-421a-a359-8b6ffded7f6f} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('24', '%k', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('24', '%k', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour24WithoutLeadingZero(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020872091 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.263996 [ 5753 ] {28ef3b83-dd63-421a-a359-8b6ffded7f6f} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('24', '%k', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour24WithoutLeadingZero(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020872091 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.296988 [ 5753 ] {79bc7b62-6fef-4eab-a0bb-ddb427052e3c} executeQuery: Code: 41. DB::Exception: Unable to parse fragment %k from -1 because read number failed: In scope SELECT parseDateTime('-1', '%k', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('-1', '%k', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity>>::type>, String const&, std::basic_string_view>&&) @ 0x00000000208a6473 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::readNumberWithVariableLength(char const*, char const*, bool, bool, bool, unsigned long, unsigned long, String const&, int&) @ 0x0000000020873143 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour24WithoutLeadingZero(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002087207f 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.297209 [ 5753 ] {79bc7b62-6fef-4eab-a0bb-ddb427052e3c} TCPHandler: Code: 41. DB::Exception: Unable to parse fragment %k from -1 because read number failed: In scope SELECT parseDateTime('-1', '%k', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity>>::type>, String const&, std::basic_string_view>&&) @ 0x00000000208a6473 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::readNumberWithVariableLength(char const*, char const*, bool, bool, bool, unsigned long, unsigned long, String const&, int&) @ 0x0000000020873143 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour24WithoutLeadingZero(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002087207f 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.298894 [ 5753 ] {3b4d61a6-f44c-4195-ad6a-4708242908f7} executeQuery: Code: 41. DB::Exception: Invalid format input 1234567 is malformed at 34567: In scope SELECT parseDateTime('1234567', '%k', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('1234567', '%k', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:37.299015 [ 5753 ] {3b4d61a6-f44c-4195-ad6a-4708242908f7} TCPHandler: Code: 41. DB::Exception: Invalid format input 1234567 is malformed at 34567: In scope SELECT parseDateTime('1234567', '%k', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:37.343318 [ 5753 ] {22755197-e1d0-4e7e-b218-c58c7aa7dbfc} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('00', '%h', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('00', '%h', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour12(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871db7 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.343590 [ 5753 ] {22755197-e1d0-4e7e-b218-c58c7aa7dbfc} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('00', '%h', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour12(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871db7 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.346283 [ 5753 ] {eef116d7-69ca-45c2-b951-2037ae46aa9b} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('13', '%h', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('13', '%h', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour12(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871db7 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.346428 [ 5753 ] {eef116d7-69ca-45c2-b951-2037ae46aa9b} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('13', '%h', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour12(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871db7 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.348706 [ 5753 ] {5f69c77d-8e24-4b91-8f90-9e2a3418b56d} executeQuery: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%h', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('123456789', '%h', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:37.348923 [ 5753 ] {5f69c77d-8e24-4b91-8f90-9e2a3418b56d} TCPHandler: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%h', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:37.362338 [ 5753 ] {f3fdf0a1-2852-464e-99ef-20ea9145151d} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('00', '%I', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('00', '%I', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour12(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871db7 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.362479 [ 5753 ] {f3fdf0a1-2852-464e-99ef-20ea9145151d} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('00', '%I', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour12(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871db7 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.364107 [ 5753 ] {a7b449ba-964a-4167-bc60-2f431db25567} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('13', '%I', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('13', '%I', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour12(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871db7 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.364226 [ 5753 ] {a7b449ba-964a-4167-bc60-2f431db25567} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('13', '%I', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour12(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871db7 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.365787 [ 5753 ] {044720d1-d298-4869-b103-ea22b883869c} executeQuery: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%I', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('123456789', '%I', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:37.365984 [ 5753 ] {044720d1-d298-4869-b103-ea22b883869c} TCPHandler: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%I', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:37.410507 [ 5753 ] {c1554d1d-7d99-41ce-aa5c-ea3aa92467fa} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('00', '%l', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('00', '%l', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour12WithoutLeadingZero(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x00000000208720d7 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.410766 [ 5753 ] {c1554d1d-7d99-41ce-aa5c-ea3aa92467fa} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('00', '%l', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour12WithoutLeadingZero(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x00000000208720d7 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.413308 [ 5753 ] {640ec028-356e-4b70-980b-8213aa456cbc} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('13', '%l', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('13', '%l', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour12WithoutLeadingZero(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x00000000208720d7 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.413502 [ 5753 ] {640ec028-356e-4b70-980b-8213aa456cbc} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('13', '%l', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour12WithoutLeadingZero(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x00000000208720d7 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.415276 [ 5753 ] {bb7c381c-df1f-48fd-bb5f-bb4d2a7cf227} executeQuery: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%l', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('123456789', '%l', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:37.415436 [ 5753 ] {bb7c381c-df1f-48fd-bb5f-bb4d2a7cf227} TCPHandler: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%l', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:37.463549 [ 5753 ] {7c557225-470b-4957-a7f8-b9cb2c556c75} executeQuery: Code: 41. DB::Exception: Value 60 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('60', '%i', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('60', '%i', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setMinute(int) @ 0x0000000020873c5d 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMinute(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002087164d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.463671 [ 5753 ] {7c557225-470b-4957-a7f8-b9cb2c556c75} TCPHandler: Code: 41. DB::Exception: Value 60 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('60', '%i', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setMinute(int) @ 0x0000000020873c5d 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMinute(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002087164d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.465276 [ 5753 ] {aa1655fe-a812-4de0-af31-f3e3b96b4952} executeQuery: Code: 41. DB::Exception: Value -29 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('-1', '%i', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('-1', '%i', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setMinute(int) @ 0x0000000020873c5d 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMinute(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002087164d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.465385 [ 5753 ] {aa1655fe-a812-4de0-af31-f3e3b96b4952} TCPHandler: Code: 41. DB::Exception: Value -29 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('-1', '%i', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setMinute(int) @ 0x0000000020873c5d 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMinute(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002087164d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.466830 [ 5753 ] {42e5c677-0992-4f60-89d2-66a132ff3464} executeQuery: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%i', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('123456789', '%i', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:37.466953 [ 5753 ] {42e5c677-0992-4f60-89d2-66a132ff3464} TCPHandler: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%i', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:37.503092 [ 5753 ] {77d5c17f-0d7f-484c-96ee-947a276d85e8} executeQuery: Code: 41. DB::Exception: Value 60 for second must be in the range [0, 59]: In scope SELECT parseDateTime('60', '%s', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('60', '%s', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setSecond(int) @ 0x0000000020873fdd 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlSecond(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871b6d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.503256 [ 5753 ] {77d5c17f-0d7f-484c-96ee-947a276d85e8} TCPHandler: Code: 41. DB::Exception: Value 60 for second must be in the range [0, 59]: In scope SELECT parseDateTime('60', '%s', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setSecond(int) @ 0x0000000020873fdd 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlSecond(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871b6d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.514468 [ 5753 ] {ad7b0560-4252-4e57-98e6-161f3559152e} executeQuery: Code: 41. DB::Exception: Value -29 for second must be in the range [0, 59]: In scope SELECT parseDateTime('-1', '%s', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('-1', '%s', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setSecond(int) @ 0x0000000020873fdd 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlSecond(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871b6d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.514674 [ 5753 ] {ad7b0560-4252-4e57-98e6-161f3559152e} TCPHandler: Code: 41. DB::Exception: Value -29 for second must be in the range [0, 59]: In scope SELECT parseDateTime('-1', '%s', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setSecond(int) @ 0x0000000020873fdd 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlSecond(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871b6d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.516533 [ 5753 ] {81f588fe-c84e-4092-8e67-055799b886e7} executeQuery: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%s', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('123456789', '%s', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:37.516671 [ 5753 ] {81f588fe-c84e-4092-8e67-055799b886e7} TCPHandler: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%s', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x00000000208a5742 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000208697d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:37.549436 [ 5753 ] {8e2f606e-0a76-45ea-9eac-4fc01c7514db} executeQuery: Code: 243. DB::Exception: Unable to parse fragment %f from 42 because mysqlMicrosecond requires size >= 6: In scope SELECT parseDateTime('42', '%f', 'UTC') = toDateTime('1970-01-01 00:00:00', 'UTC'). (NOT_ENOUGH_SPACE) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('42', '%f', 'UTC') = toDateTime('1970-01-01 00:00:00', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, String const&>(int, FormatStringHelperImpl::type, std::type_identity>>::type, std::type_identity::type>, String const&, std::basic_string_view>&&, String const&) @ 0x00000000208a5cb4 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::checkSpace(char const*, char const*, unsigned long, String const&, String const&) @ 0x0000000020872d39 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMicrosecond(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086f50e 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:09:37.579325 [ 10241 ] {cb41e7de-9ff9-495a-90d8-49ef55bdfbc1} executeQuery: Code: 44. DB::Exception: Illegal column '01GWJWKW30MFPQJRYEAF4XFZ9' of argument of function ULIDStringToDateTime, ULID must be 26 characters long: In scope SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9', 'America/Costa_Rica'). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:57450) (comment: 02668_ulid_decoding.sql) (in query: SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9', 'America/Costa_Rica');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, unsigned long const&) @ 0x0000000018209c51 4. DB::FunctionULIDStringToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018217618 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:37.579449 [ 5753 ] {8e2f606e-0a76-45ea-9eac-4fc01c7514db} TCPHandler: Code: 243. DB::Exception: Unable to parse fragment %f from 42 because mysqlMicrosecond requires size >= 6: In scope SELECT parseDateTime('42', '%f', 'UTC') = toDateTime('1970-01-01 00:00:00', 'UTC'). (NOT_ENOUGH_SPACE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, String const&>(int, FormatStringHelperImpl::type, std::type_identity>>::type, std::type_identity::type>, String const&, std::basic_string_view>&&, String const&) @ 0x00000000208a5cb4 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::checkSpace(char const*, char const*, unsigned long, String const&, String const&) @ 0x0000000020872d39 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMicrosecond(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086f50e 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:09:37.579521 [ 10241 ] {cb41e7de-9ff9-495a-90d8-49ef55bdfbc1} TCPHandler: Code: 44. DB::Exception: Illegal column '01GWJWKW30MFPQJRYEAF4XFZ9' of argument of function ULIDStringToDateTime, ULID must be 26 characters long: In scope SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9', 'America/Costa_Rica'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, unsigned long const&) @ 0x0000000018209c51 4. DB::FunctionULIDStringToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018217618 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:37.607304 [ 10241 ] {ec1968cc-4573-437d-a865-666b601148ac} executeQuery: Code: 36. DB::Exception: Cannot load time zone America/Costa_Ric: In scope SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9E', 'America/Costa_Ric'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:57450) (comment: 02668_ulid_decoding.sql) (in query: SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9E', 'America/Costa_Ric');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000002465a6b8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x0000000024657601 6. ./src/Common/DateLUT.h:62: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002f463950 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:23: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f464f88 8. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int const&, String&) @ 0x0000000018219161 9. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int const&, String&, void>(std::allocator const&, unsigned int const&, String&) @ 0x0000000018218ea6 10. DB::FunctionULIDStringToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018217e46 11. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 12. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 13. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.634188 [ 5753 ] {553a9bd7-df03-441e-90d4-14c0455cde3d} executeQuery: Code: 41. DB::Exception: Unable to parse fragment %f from ABCD because  is not a number: In scope SELECT parseDateTime('12ABCD', '%f', 'UTC') = toDateTime('1970-01-01 00:00:00', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('12ABCD', '%f', 'UTC') = toDateTime('1970-01-01 00:00:00', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, String>(int, FormatStringHelperImpl::type, std::type_identity>>::type, std::type_identity::type>, String const&, std::basic_string_view>&&, String&&) @ 0x00000000208a6dd4 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMicrosecond(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086f77b 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:09:37.634199 [ 10241 ] {ec1968cc-4573-437d-a865-666b601148ac} TCPHandler: Code: 36. DB::Exception: Cannot load time zone America/Costa_Ric: In scope SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9E', 'America/Costa_Ric'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000002465a6b8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x0000000024657601 6. ./src/Common/DateLUT.h:62: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002f463950 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:23: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f464f88 8. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int const&, String&) @ 0x0000000018219161 9. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int const&, String&, void>(std::allocator const&, unsigned int const&, String&) @ 0x0000000018218ea6 10. DB::FunctionULIDStringToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018217e46 11. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 12. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 13. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.634421 [ 5753 ] {553a9bd7-df03-441e-90d4-14c0455cde3d} TCPHandler: Code: 41. DB::Exception: Unable to parse fragment %f from ABCD because  is not a number: In scope SELECT parseDateTime('12ABCD', '%f', 'UTC') = toDateTime('1970-01-01 00:00:00', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>, String>(int, FormatStringHelperImpl::type, std::type_identity>>::type, std::type_identity::type>, String const&, std::basic_string_view>&&, String&&) @ 0x00000000208a6dd4 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMicrosecond(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086f77b 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:09:37.636124 [ 10241 ] {bcc87545-942a-4149-875f-80f0ec480133} executeQuery: Code: 44. DB::Exception: Illegal column '01GWJWKW30MFPQJRYEAF4XFZ9E0' of argument of function ULIDStringToDateTime, ULID must be 26 characters long: In scope SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9E0'). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:57450) (comment: 02668_ulid_decoding.sql) (in query: SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9E0');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, unsigned long const&) @ 0x0000000018209c51 4. DB::FunctionULIDStringToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018217618 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:37.636237 [ 10241 ] {bcc87545-942a-4149-875f-80f0ec480133} TCPHandler: Code: 44. DB::Exception: Illegal column '01GWJWKW30MFPQJRYEAF4XFZ9E0' of argument of function ULIDStringToDateTime, ULID must be 26 characters long: In scope SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9E0'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, unsigned long const&) @ 0x0000000018209c51 4. DB::FunctionULIDStringToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018217618 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:37.669040 [ 10241 ] {26da252e-85e3-4e0f-86cd-476a010d0ce8} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function ULIDStringToDateTime. Must be String or FixedString(26).: In scope SELECT ULIDStringToDateTime(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:57450) (comment: 02668_ulid_decoding.sql) (in query: SELECT ULIDStringToDateTime(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionULIDStringToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001821825d 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:37.696720 [ 5753 ] {36c46ae2-9e51-41d1-918c-ef39e0071d5b} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for function parseDateTime provided 1 (String), expected 2 to 3 ('time' : String, 'format' : String, ['timezone' : const String]): In scope SELECT parseDateTime('12 AM'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: -- Error handling select parseDateTime('12 AM');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002086a1a7 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:37.696770 [ 10241 ] {26da252e-85e3-4e0f-86cd-476a010d0ce8} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function ULIDStringToDateTime. Must be String or FixedString(26).: In scope SELECT ULIDStringToDateTime(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionULIDStringToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001821825d 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:37.696984 [ 5753 ] {36c46ae2-9e51-41d1-918c-ef39e0071d5b} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for function parseDateTime provided 1 (String), expected 2 to 3 ('time' : String, 'format' : String, ['timezone' : const String]): In scope SELECT parseDateTime('12 AM'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002086a1a7 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:37.699173 [ 10241 ] {ab6b1829-f8fa-4e23-a717-5be3e80d667a} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function ULIDStringToDateTime. Must be String or FixedString(26).: In scope SELECT ULIDStringToDateTime(1, 2). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:57450) (comment: 02668_ulid_decoding.sql) (in query: SELECT ULIDStringToDateTime(1, 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionULIDStringToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001821825d 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:37.699197 [ 5753 ] {0f12463c-4149-4885-9ee0-6f6e9b6bbf1a} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for function parseDateTime provided 4 (String, String, String, String), expected 2 to 3 ('time' : String, 'format' : String, ['timezone' : const String]): In scope SELECT parseDateTime('12 AM', '%h %p', 'UTC', 'a fourth argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('12 AM', '%h %p', 'UTC', 'a fourth argument');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002086a1a7 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:37.699300 [ 10241 ] {ab6b1829-f8fa-4e23-a717-5be3e80d667a} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function ULIDStringToDateTime. Must be String or FixedString(26).: In scope SELECT ULIDStringToDateTime(1, 2). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionULIDStringToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001821825d 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:37.699320 [ 5753 ] {0f12463c-4149-4885-9ee0-6f6e9b6bbf1a} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for function parseDateTime provided 4 (String, String, String, String), expected 2 to 3 ('time' : String, 'format' : String, ['timezone' : const String]): In scope SELECT parseDateTime('12 AM', '%h %p', 'UTC', 'a fourth argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002086a1a7 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:37.724659 [ 5753 ] {968ddafb-7ca7-4fe4-be26-1c90de008554} executeQuery: Code: 44. DB::Exception: Illegal type of argument #3 'timezone' of function parseDateTime, expected const String, got String: In scope SELECT parseDateTime('', '', toString(number)) FROM numbers(13). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: -- Fuzzer crash bug #53715 select parseDateTime('', '', toString(number)) from numbers(13);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002086a1a7 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:37.724901 [ 5753 ] {968ddafb-7ca7-4fe4-be26-1c90de008554} TCPHandler: Code: 44. DB::Exception: Illegal type of argument #3 'timezone' of function parseDateTime, expected const String, got String: In scope SELECT parseDateTime('', '', toString(number)) FROM numbers(13). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002086a1a7 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:37.727034 [ 5753 ] {f3032f1d-2cd7-4cb9-80b8-e80344765fec} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('Aug 13, 2022, 7:58:32 PM', '%b %e, %G, %h:%i:%s %p', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: -- %h select parseDateTime('Aug 13, 2022, 7:58:32 PM', '%b %e, %G, %h:%i:%s %p', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour12(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871db7 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.727152 [ 5753 ] {f3032f1d-2cd7-4cb9-80b8-e80344765fec} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('Aug 13, 2022, 7:58:32 PM', '%b %e, %G, %h:%i:%s %p', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour12(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871db7 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.735991 [ 5753 ] {54de34ff-6c32-4d8f-aa0d-2a585ab74653} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('Aug 13, 2022, 7:58:32', '%b %e, %G, %H:%i:%s', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: -- %H select parseDateTime('Aug 13, 2022, 7:58:32', '%b %e, %G, %H:%i:%s', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour24(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871e11 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.736133 [ 5753 ] {54de34ff-6c32-4d8f-aa0d-2a585ab74653} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('Aug 13, 2022, 7:58:32', '%b %e, %G, %H:%i:%s', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, int&, int&, int&, bool&, bool&) @ 0x00000000208a762e 4. DB::(anonymous namespace)::DateTime::setHour(int, bool, bool) @ 0x0000000020873f19 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlHour24(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x0000000020871e11 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.745865 [ 5753 ] {01e040b7-5245-47f6-9f04-36577078b4fa} executeQuery: Code: 41. DB::Exception: Value 64 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('8 13, 2022, 7:58:32', '%m %e, %G, %k:%i:%s', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:57370) (comment: 02668_parse_datetime.sql) (in query: -- %m select parseDateTime('8 13, 2022, 7:58:32', '%m %e, %G, %k:%i:%s', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setMonth(int) @ 0x0000000020872f25 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMonth(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086ec8d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:37.746030 [ 5753 ] {01e040b7-5245-47f6-9f04-36577078b4fa} TCPHandler: Code: 41. DB::Exception: Value 64 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('8 13, 2022, 7:58:32', '%m %e, %G, %k:%i:%s', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x00000000187c1e1a 4. DB::(anonymous namespace)::DateTime::setMonth(int) @ 0x0000000020872f25 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::Instruction::mysqlMonth(char const*, char const*, String const&, DB::(anonymous namespace)::DateTime&) @ 0x000000002086ec8d 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020869187 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:09:38.623513 [ 10241 ] {16e9face-c9e7-4d00-b5bc-bdbd1d155d0a} executeQuery: Code: 36. DB::Exception: Cannot drop column x because it's affected by mutation with ID '0000000001' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000001'". (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:57552) (comment: 02597_column_update_and_replication.sql) (in query: ALTER TABLE test DROP COLUMN x SETTINGS mutations_sync = 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String const&, String const&) @ 0x0000000032c025e1 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x0000000032b467e3 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3f009 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:38.623797 [ 10241 ] {16e9face-c9e7-4d00-b5bc-bdbd1d155d0a} TCPHandler: Code: 36. DB::Exception: Cannot drop column x because it's affected by mutation with ID '0000000001' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000001'". (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String const&, String const&) @ 0x0000000032c025e1 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x0000000032b467e3 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3f009 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:39.659515 [ 730 ] {40b30c48-5708-4ef0-bd39-7a14a36fdd2d} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.3.12.76.altinitystable) (from [::1]:56032) (in query: select _path, _file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:39.659662 [ 730 ] {40b30c48-5708-4ef0-bd39-7a14a36fdd2d} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:39.768983 [ 10241 ] {64439392-cfb4-4fb0-b8d4-de6cb43b29f4} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.3.12.76.altinitystable) (from [::1]:56058) (in query: select _path, _file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:39.769100 [ 10241 ] {64439392-cfb4-4fb0-b8d4-de6cb43b29f4} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:39.836592 [ 730 ] {35faabd9-04d3-41bc-846a-923c2eda666c} executeQuery: Code: 36. DB::Exception: Cannot drop column x because it's affected by mutation with ID '0000000001' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000001'". (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:56056) (comment: 02597_column_update_tricy_expression_and_replication.sql) (in query: ALTER TABLE test DROP COLUMN x SETTINGS mutations_sync = 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String const&, String const&) @ 0x0000000032c025e1 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x0000000032b4691b 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3f009 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:39.836907 [ 730 ] {35faabd9-04d3-41bc-846a-923c2eda666c} TCPHandler: Code: 36. DB::Exception: Cannot drop column x because it's affected by mutation with ID '0000000001' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000001'". (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String const&, String const&) @ 0x0000000032c025e1 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x0000000032b4691b 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3f009 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:39.843353 [ 10241 ] {3af10274-5b7c-4db3-9ee2-4ef727a4cb88} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.3.12.76.altinitystable) (from [::1]:56074) (in query: select _path, _file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:39.843535 [ 10241 ] {3af10274-5b7c-4db3-9ee2-4ef727a4cb88} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:40.965669 [ 14973 ] {7eef8ec9-5702-4b5c-8eca-7f4d17fec530} executeQuery: Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: x: (at row 1) : While executing BSONEachRowRowInputFormat. (INCORRECT_DATA) (version 24.3.12.76.altinitystable) (from [::1]:56198) (comment: 02590_bson_duplicate_column.sql) (in query: select * from format(BSONEachRow, 'x UInt32, y UInt32', x'1a0000001078002a0000001078002a0000001079002a00000000');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&) @ 0x0000000033693f3b 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:808: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003368e795 5. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 7. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 11. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 16. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:09:40.965929 [ 14973 ] {7eef8ec9-5702-4b5c-8eca-7f4d17fec530} TCPHandler: Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: x: (at row 1) : While executing BSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&) @ 0x0000000033693f3b 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:808: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003368e795 5. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 7. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 11. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 16. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:09:41.029773 [ 11399 ] {d2326337-1487-4b8b-b387-1d422d020ee5} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 117. DB::Exception: Size of BSON document is invalid. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:0: DB::fileSegmentationEngineBSONEachRow(DB::ReadBuffer&, DB::Memory>&, unsigned long, unsigned long) @ 0x0000000033692498 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 6. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 7. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 9. ? @ 0x00007fe1df9bbac3 10. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:41.030363 [ 14973 ] {d2326337-1487-4b8b-b387-1d422d020ee5} executeQuery: Code: 117. DB::Exception: Size of BSON document is invalid: While executing ParallelParsingBlockInputFormat. (INCORRECT_DATA) (version 24.3.12.76.altinitystable) (from [::1]:56212) (comment: 02589_bson_invalid_document_size.sql) (in query: select * from format(BSONEachRow, 'x UInt32', x'00000000');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:0: DB::fileSegmentationEngineBSONEachRow(DB::ReadBuffer&, DB::Memory>&, unsigned long, unsigned long) @ 0x0000000033692498 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 6. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 7. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 9. ? @ 0x00007fe1df9bbac3 10. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:41.030518 [ 14973 ] {d2326337-1487-4b8b-b387-1d422d020ee5} TCPHandler: Code: 117. DB::Exception: Size of BSON document is invalid: While executing ParallelParsingBlockInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:0: DB::fileSegmentationEngineBSONEachRow(DB::ReadBuffer&, DB::Memory>&, unsigned long, unsigned long) @ 0x0000000033692498 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 6. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 7. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 9. ? @ 0x00007fe1df9bbac3 10. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:42.194290 [ 3522 ] {91e6c9e4-1b9e-44b9-9895-2c93cea0e852} executeQuery: Code: 53. DB::Exception: CAST AS Map can only be performed from tuples of array. Got: Tuple(Tuple(String, UInt8), Tuple(String, UInt8)): In scope SELECT CAST((('a', 1), ('b', 2)), 'Map(String, UInt8)'). (TYPE_MISMATCH) (version 24.3.12.76.altinitystable) (from [::1]:56392) (comment: 02583_map_literal_cast.sql) (in query: SELECT CAST((('a', 1), ('b', 2)), 'Map(String, UInt8)');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000018259a0c 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e5b2 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6178: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b2243 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:42.194515 [ 3522 ] {91e6c9e4-1b9e-44b9-9895-2c93cea0e852} TCPHandler: Code: 53. DB::Exception: CAST AS Map can only be performed from tuples of array. Got: Tuple(Tuple(String, UInt8), Tuple(String, UInt8)): In scope SELECT CAST((('a', 1), ('b', 2)), 'Map(String, UInt8)'). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000018259a0c 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e5b2 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6178: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b2243 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:42.197245 [ 3522 ] {ea8efb4d-b41b-4339-b7a8-576643ff729c} executeQuery: Code: 53. DB::Exception: CAST AS Map can only be performed from tuples of array. Got: Tuple(Tuple(String, UInt8), Tuple(String, UInt8)): In scope SELECT CAST((('abc', 22), ('def', 33)), 'Map(String, UInt8)'). (TYPE_MISMATCH) (version 24.3.12.76.altinitystable) (from [::1]:56392) (comment: 02583_map_literal_cast.sql) (in query: SELECT CAST((('abc', 22), ('def', 33)), 'Map(String, UInt8)');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000018259a0c 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e5b2 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6178: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b2243 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:42.197359 [ 3522 ] {ea8efb4d-b41b-4339-b7a8-576643ff729c} TCPHandler: Code: 53. DB::Exception: CAST AS Map can only be performed from tuples of array. Got: Tuple(Tuple(String, UInt8), Tuple(String, UInt8)): In scope SELECT CAST((('abc', 22), ('def', 33)), 'Map(String, UInt8)'). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000018259a0c 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e5b2 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6178: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b2243 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:42.199155 [ 3522 ] {f6185a90-a723-4e77-a742-b1905e582d97} executeQuery: Code: 53. DB::Exception: CAST AS Map can only be performed from tuples of array. Got: Tuple(Tuple(UInt8, Array(UInt8)), Tuple(UInt8, Array(UInt8))): In scope SELECT CAST(((10, [11, 12]), (13, [14, 15])), 'Map(UInt8, Array(UInt8))'). (TYPE_MISMATCH) (version 24.3.12.76.altinitystable) (from [::1]:56392) (comment: 02583_map_literal_cast.sql) (in query: SELECT CAST(((10, [11, 12]), (13, [14, 15])), 'Map(UInt8, Array(UInt8))');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000018259a0c 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e5b2 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6178: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b2243 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:42.199270 [ 3522 ] {f6185a90-a723-4e77-a742-b1905e582d97} TCPHandler: Code: 53. DB::Exception: CAST AS Map can only be performed from tuples of array. Got: Tuple(Tuple(UInt8, Array(UInt8)), Tuple(UInt8, Array(UInt8))): In scope SELECT CAST(((10, [11, 12]), (13, [14, 15])), 'Map(UInt8, Array(UInt8))'). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000018259a0c 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e5b2 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6178: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b2243 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:42.201575 [ 3522 ] {10814aa7-2775-41b8-81af-687ea99864a3} executeQuery: Code: 53. DB::Exception: CAST AS Map can only be performed from tuples of array. Got: Tuple(Tuple(String, Tuple(String, Array(UInt8))), Tuple(String, Tuple(String, Array(UInt8)))): In scope SELECT CAST((('ghj', ('klm', [16, 17])), ('nop', ('rst', [18]))), 'Map(String, Map(String, Array(UInt8)))'). (TYPE_MISMATCH) (version 24.3.12.76.altinitystable) (from [::1]:56392) (comment: 02583_map_literal_cast.sql) (in query: SELECT CAST((('ghj', (('klm', [16, 17]))), ('nop', (('rst', [18])))), 'Map(String, Map(String, Array(UInt8)))');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000018259a0c 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e5b2 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6178: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b2243 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:42.201718 [ 3522 ] {10814aa7-2775-41b8-81af-687ea99864a3} TCPHandler: Code: 53. DB::Exception: CAST AS Map can only be performed from tuples of array. Got: Tuple(Tuple(String, Tuple(String, Array(UInt8))), Tuple(String, Tuple(String, Array(UInt8)))): In scope SELECT CAST((('ghj', ('klm', [16, 17])), ('nop', ('rst', [18]))), 'Map(String, Map(String, Array(UInt8)))'). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000018259a0c 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e5b2 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6178: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b2243 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:43.373602 [ 12524 ] {a681a1a3-c8bf-41ae-808c-552c9dcbee6f} executeQuery: Code: 182. DB::Exception: Table expression test_bnpux8xl.m AS __table1 does not support column __table1.f in PREWHERE. In query SELECT * FROM m PREWHERE f = 1 ORDER BY a ASC. (ILLEGAL_PREWHERE) (version 24.3.12.76.altinitystable) (from [::1]:56588) (comment: 02575_merge_prewhere_ephemeral.sql) (in query: SELECT * FROM m PREWHERE f = 1 ORDER BY a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000310389cf 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000310343c1 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008f36 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:43.373807 [ 12524 ] {a681a1a3-c8bf-41ae-808c-552c9dcbee6f} TCPHandler: Code: 182. DB::Exception: Table expression test_bnpux8xl.m AS __table1 does not support column __table1.f in PREWHERE. In query SELECT * FROM m PREWHERE f = 1 ORDER BY a ASC. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000310389cf 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000310343c1 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008f36 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:43.376830 [ 14974 ] {b0c60bbb-ff93-4a8c-97f0-7951800a69f3} executeQuery: Code: 182. DB::Exception: Table expression test_ajbkf9t4.m AS __table1 does not support column __table1.f in PREWHERE. In query SELECT * FROM m PREWHERE f = 0. (ILLEGAL_PREWHERE) (version 24.3.12.76.altinitystable) (from [::1]:56604) (comment: 02575_merge_prewhere_different_default_kind.sql) (in query: SELECT * FROM m PREWHERE f = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000310389cf 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000310343c1 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008f36 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:43.376990 [ 14974 ] {b0c60bbb-ff93-4a8c-97f0-7951800a69f3} TCPHandler: Code: 182. DB::Exception: Table expression test_ajbkf9t4.m AS __table1 does not support column __table1.f in PREWHERE. In query SELECT * FROM m PREWHERE f = 0. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000310389cf 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000310343c1 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008f36 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:43.698745 [ 12524 ] {d07cac66-af1e-41e0-a470-bd2c4a9ec280} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '{' before: 'null}}}': (while reading the value of nested key merged_by): (while reading the value of nested key pull_request): (while reading the value of key payload): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:56634) (comment: 02573_insert_null_as_default_null_as_empty_nested.sql) (in query: select * from format(JSONEachRow, 'payload Tuple(pull_request Tuple(merged_by Tuple(login String)))', '{"payload" : {"pull_request": {"merged_by": null}}}') settings input_format_null_as_default=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./src/IO/ReadHelpers.h:203: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f6a8060 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'(DB::IColumn&, unsigned long)::operator()(DB::IColumn&, unsigned long) const @ 0x000000002f6ad894 7. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:423: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x000000002f6acaec 8. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f6a79e3 9. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'(DB::IColumn&, unsigned long)::operator()(DB::IColumn&, unsigned long) const @ 0x000000002f6ad894 10. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:423: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x000000002f6acaec 11. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f6a79e3 12. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000337c0b03 13. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:137: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef010 14. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef78b 15. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000337f0390 16. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 17. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 18. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 22. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 23. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 25. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 26. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 27. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 29. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 30. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 2025.03.05 21:09:43.699025 [ 12524 ] {d07cac66-af1e-41e0-a470-bd2c4a9ec280} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '{' before: 'null}}}': (while reading the value of nested key merged_by): (while reading the value of nested key pull_request): (while reading the value of key payload): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./src/IO/ReadHelpers.h:203: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f6a8060 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'(DB::IColumn&, unsigned long)::operator()(DB::IColumn&, unsigned long) const @ 0x000000002f6ad894 7. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:423: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x000000002f6acaec 8. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f6a79e3 9. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'(DB::IColumn&, unsigned long)::operator()(DB::IColumn&, unsigned long) const @ 0x000000002f6ad894 10. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:423: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x000000002f6acaec 11. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f6a79e3 12. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000337c0b03 13. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:137: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef010 14. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef78b 15. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000337f0390 16. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 17. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 18. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 22. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 23. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 25. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 26. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 27. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 29. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 30. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 2025.03.05 21:09:43.752747 [ 12524 ] {e6de16f1-d05d-4338-be2e-0f1e0776064f} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '{' before: 'null}}}': (while reading the value of key payload): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:56634) (comment: 02573_insert_null_as_default_null_as_empty_nested.sql) (in query: select * from format(JSONEachRow, 'payload Map(String, Map(String, Map(String, String)))', '{"payload" : {"pull_request": {"merged_by": null}}}') settings input_format_null_as_default=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./src/IO/ReadHelpers.h:203: DB::SerializationMap::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f626b7d 6. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:194: DB::SerializationMap::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f6265f1 7. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:194: DB::SerializationMap::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f6265f1 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000337c0b03 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:137: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef010 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef78b 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000337f0390 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 14. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 18. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 23. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 27. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 2025.03.05 21:09:43.753006 [ 12524 ] {e6de16f1-d05d-4338-be2e-0f1e0776064f} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '{' before: 'null}}}': (while reading the value of key payload): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./src/IO/ReadHelpers.h:203: DB::SerializationMap::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f626b7d 6. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:194: DB::SerializationMap::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f6265f1 7. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:194: DB::SerializationMap::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f6265f1 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000337c0b03 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:137: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef010 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef78b 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000337f0390 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 14. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 18. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 23. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 27. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 2025.03.05 21:09:43.810559 [ 12524 ] {beb8de6b-383b-4f4d-a666-e5e64639bbc6} executeQuery: Code: 130. DB::Exception: Array does not start with '[' character: (while reading the value of key payload): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_READ_ARRAY_FROM_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:56634) (comment: 02573_insert_null_as_default_null_as_empty_nested.sql) (in query: select * from format(JSONEachRow, 'payload Array(String)', '{"payload" : null}') settings input_format_null_as_default=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:440: DB::SerializationArray::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5bc90b 5. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000337c0b03 6. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:137: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef010 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef78b 8. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000337f0390 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 11. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 15. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 18. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 19. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 20. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:09:43.810994 [ 12524 ] {beb8de6b-383b-4f4d-a666-e5e64639bbc6} TCPHandler: Code: 130. DB::Exception: Array does not start with '[' character: (while reading the value of key payload): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_READ_ARRAY_FROM_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:440: DB::SerializationArray::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5bc90b 5. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x00000000337c0b03 6. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:137: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef010 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x00000000337ef78b 8. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000337f0390 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 11. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 15. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 18. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4f1fe6 19. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 20. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:09:43.899613 [ 14974 ] {d8c018e3-16b2-467b-9af4-0a93ad1e00c2} executeQuery: Code: 60. DB::Exception: Table test_xmi0gg13.receiver_02572 does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:56656) (comment: 02572_materialized_views_ignore_errors.sql) (in query: -- ensure that insert fails insert into proxy_02572 values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:710: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000003293ccb0 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x0000000032935ad6 11. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:179: DB::DistributedSink::writeAsync(DB::Block const&) @ 0x0000000032935159 12. ./src/Core/Block.h:25: DB::DistributedSink::consume(DB::Chunk) @ 0x0000000032932f58 13. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 19. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:43.899778 [ 14974 ] {d8c018e3-16b2-467b-9af4-0a93ad1e00c2} TCPHandler: Code: 60. DB::Exception: Table test_xmi0gg13.receiver_02572 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:710: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000003293ccb0 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x0000000032935ad6 11. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:179: DB::DistributedSink::writeAsync(DB::Block const&) @ 0x0000000032935159 12. ./src/Core/Block.h:25: DB::DistributedSink::consume(DB::Chunk) @ 0x0000000032932f58 13. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 19. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:43.910259 [ 14974 ] {c4a57f69-e80d-4eab-ae4e-7592664cf157} PushingToViews: Cannot push to the storage, ignoring the error: Code: 60. DB::Exception: Table test_xmi0gg13.receiver_02572 does not exist: while pushing to view test_xmi0gg13.push_to_proxy_mv_02572 (73c02be4-ea93-46d0-99e4-3d6aa6c62f90). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:710: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000003293ccb0 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x0000000032935ad6 11. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:179: DB::DistributedSink::writeAsync(DB::Block const&) @ 0x0000000032935159 12. ./src/Core/Block.h:25: DB::DistributedSink::consume(DB::Chunk) @ 0x0000000032932f58 13. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 19. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:44.181127 [ 14974 ] {da934c60-e338-4a57-b4aa-490dce5eed83} executeQuery: Code: 60. DB::Exception: Table test_xmi0gg13.receiver_02572 does not exist: while pushing to view test_xmi0gg13.push_to_proxy_mv_02572 (73c02be4-ea93-46d0-99e4-3d6aa6c62f90). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:56656) (comment: 02572_materialized_views_ignore_errors.sql) (in query: -- materialized_views_ignore_errors=0 insert into data_02572 values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:710: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000003293ccb0 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x0000000032935ad6 11. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:179: DB::DistributedSink::writeAsync(DB::Block const&) @ 0x0000000032935159 12. ./src/Core/Block.h:25: DB::DistributedSink::consume(DB::Chunk) @ 0x0000000032932f58 13. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 19. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:44.181277 [ 14974 ] {da934c60-e338-4a57-b4aa-490dce5eed83} TCPHandler: Code: 60. DB::Exception: Table test_xmi0gg13.receiver_02572 does not exist: while pushing to view test_xmi0gg13.push_to_proxy_mv_02572 (73c02be4-ea93-46d0-99e4-3d6aa6c62f90). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:710: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000003293ccb0 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x0000000032935ad6 11. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:179: DB::DistributedSink::writeAsync(DB::Block const&) @ 0x0000000032935159 12. ./src/Core/Block.h:25: DB::DistributedSink::consume(DB::Chunk) @ 0x0000000032932f58 13. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 19. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:45.417676 [ 10241 ] {1dbadaaa-a992-4159-bac6-1200cffcf6ae} executeQuery: Code: 80. DB::Exception: Failed to rewrite ' test_1yp6h411.t1 AS __table1, test_1yp6h411.t2 AS __table2, (SELECT __table4.a AS x FROM test_1yp6h411.t3 AS __table4 WHERE (__table4.a + 1) = __table4.b) AS __table3' to INNER JOIN: no equi-join conditions found in WHERE clause. You may set setting `cross_to_inner_join_rewrite` to `1` to allow slow CROSS JOIN for this case. (INCORRECT_QUERY) (version 24.3.12.76.altinitystable) (from [::1]:56914) (comment: 02564_analyzer_cross_to_inner.sql) (in query: -- { echoOff } SELECT * FROM t1, t2, (SELECT a as x from t3 where a + 1 = b ) as t3 WHERE t1.a = if(t2.b > 0, t2.a, 0) SETTINGS cross_to_inner_join_rewrite = 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:0: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x0000000030f10b9e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CrossToInnerJoinPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030f0e969 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:45.417966 [ 10241 ] {1dbadaaa-a992-4159-bac6-1200cffcf6ae} TCPHandler: Code: 80. DB::Exception: Failed to rewrite ' test_1yp6h411.t1 AS __table1, test_1yp6h411.t2 AS __table2, (SELECT __table4.a AS x FROM test_1yp6h411.t3 AS __table4 WHERE (__table4.a + 1) = __table4.b) AS __table3' to INNER JOIN: no equi-join conditions found in WHERE clause. You may set setting `cross_to_inner_join_rewrite` to `1` to allow slow CROSS JOIN for this case. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:0: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x0000000030f10b9e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CrossToInnerJoinPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030f0e969 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:46.582388 [ 730 ] {test_jjdqmrkv_23154} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 1 ('BAD'): BAD SQL. Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:49294) (comment: 02564_query_id_header.sh) (in query: BAD SQL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:46.582630 [ 730 ] {test_jjdqmrkv_23154} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 1 ('BAD'): BAD SQL. Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:46.990260 [ 14973 ] {0d76c61f-c440-4ded-a335-ede3951ee3d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 1: In scope SELECT regexpExtract('100-200'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:57066) (comment: 02562_regexp_extract.sql) (in query: select regexpExtract('100-200');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000001806a053 4. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213c637c 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:46.990487 [ 14973 ] {0d76c61f-c440-4ded-a335-ede3951ee3d1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 1: In scope SELECT regexpExtract('100-200'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000001806a053 4. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213c637c 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:46.992659 [ 14973 ] {2a7a1c3f-9d58-4e39-a4d8-04ae5e9c3a0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 4: In scope SELECT regexpExtract('100-200', '(\\d+)-(\\d+)', 1, 2). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:57066) (comment: 02562_regexp_extract.sql) (in query: select regexpExtract('100-200', '(\\d+)-(\\d+)', 1, 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000001806a053 4. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213c637c 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:46.992771 [ 14973 ] {2a7a1c3f-9d58-4e39-a4d8-04ae5e9c3a0a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 4: In scope SELECT regexpExtract('100-200', '(\\d+)-(\\d+)', 1, 2). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000001806a053 4. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213c637c 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:47.016074 [ 14973 ] {3ca2c827-187f-43b3-8a94-60ba35966772} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'haystack' of function regexpExtract, expected String, got FixedString(10): In scope SELECT regexpExtract(CAST('100-200', 'FixedString(10)'), '(\\d+)-(\\d+)', 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:57066) (comment: 02562_regexp_extract.sql) (in query: select regexpExtract(cast('100-200' as FixedString(10)), '(\\d+)-(\\d+)', 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213c6243 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:47.016464 [ 14973 ] {3ca2c827-187f-43b3-8a94-60ba35966772} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'haystack' of function regexpExtract, expected String, got FixedString(10): In scope SELECT regexpExtract(CAST('100-200', 'FixedString(10)'), '(\\d+)-(\\d+)', 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213c6243 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:47.018536 [ 14973 ] {0f52379a-c568-4060-920e-4429e74adf61} executeQuery: Code: 43. DB::Exception: Illegal type of argument #2 'pattern' of function regexpExtract, expected const String, got FixedString(20): In scope SELECT regexpExtract('100-200', CAST('(\\d+)-(\\d+)', 'FixedString(20)'), 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:57066) (comment: 02562_regexp_extract.sql) (in query: select regexpExtract('100-200', cast('(\\d+)-(\\d+)' as FixedString(20)), 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213c6243 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:47.018641 [ 14973 ] {0f52379a-c568-4060-920e-4429e74adf61} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #2 'pattern' of function regexpExtract, expected const String, got FixedString(20): In scope SELECT regexpExtract('100-200', CAST('(\\d+)-(\\d+)', 'FixedString(20)'), 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213c6243 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:47.021566 [ 14973 ] {e95be5bf-b82a-45f8-aa17-6363125ed2d0} executeQuery: Code: 43. DB::Exception: Illegal type of argument #3 'index' of function regexpExtract, expected Integer, got String: In scope SELECT regexpExtract('100-200', '(\\d+)-(\\d+)', 'a'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:57066) (comment: 02562_regexp_extract.sql) (in query: select regexpExtract('100-200', '(\\d+)-(\\d+)', 'a');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213c6243 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:47.021670 [ 14973 ] {e95be5bf-b82a-45f8-aa17-6363125ed2d0} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #3 'index' of function regexpExtract, expected Integer, got String: In scope SELECT regexpExtract('100-200', '(\\d+)-(\\d+)', 'a'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213c6243 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:47.023310 [ 14973 ] {48370375-5c0c-4b37-a377-99d8c6ac1a17} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'haystack' of function regexpExtract, expected String, got UInt8: In scope SELECT regexpExtract(100, '(\\d+)-(\\d+)', 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:57066) (comment: 02562_regexp_extract.sql) (in query: select regexpExtract(100, '(\\d+)-(\\d+)', 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213c6243 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:47.023422 [ 14973 ] {48370375-5c0c-4b37-a377-99d8c6ac1a17} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'haystack' of function regexpExtract, expected String, got UInt8: In scope SELECT regexpExtract(100, '(\\d+)-(\\d+)', 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213c6243 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:47.024856 [ 14973 ] {9a7ed719-2921-40b8-a875-5c91523574fa} executeQuery: Code: 43. DB::Exception: Illegal type of argument #2 'pattern' of function regexpExtract, expected const String, got UInt8: In scope SELECT regexpExtract('100-200', 1, 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:57066) (comment: 02562_regexp_extract.sql) (in query: select regexpExtract('100-200', 1, 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213c6243 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:47.024972 [ 14973 ] {9a7ed719-2921-40b8-a875-5c91523574fa} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #2 'pattern' of function regexpExtract, expected const String, got UInt8: In scope SELECT regexpExtract('100-200', 1, 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213c6243 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:47.026521 [ 14973 ] {aabc0d0d-2e1f-4515-82e2-e5f24a0abc2e} executeQuery: Code: 44. DB::Exception: Illegal type of argument #2 'pattern' of function regexpExtract, expected const String, got String: In scope SELECT regexpExtract('100-200', materialize('(\\d+)-(\\d+)'), 1). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:57066) (comment: 02562_regexp_extract.sql) (in query: select regexpExtract('100-200', materialize('(\\d+)-(\\d+)'), 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213c6243 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:47.026626 [ 14973 ] {aabc0d0d-2e1f-4515-82e2-e5f24a0abc2e} TCPHandler: Code: 44. DB::Exception: Illegal type of argument #2 'pattern' of function regexpExtract, expected const String, got String: In scope SELECT regexpExtract('100-200', materialize('(\\d+)-(\\d+)'), 1). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionRegexpExtract::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213c6243 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:47.054391 [ 14973 ] {5f3dc10f-8576-4239-9960-d335b9bba778} executeQuery: Code: 353. DB::Exception: Index value 3 for regexp pattern `(\d+)-(\d+)` in function regexpExtract is out-of-range, should be in [0, 3): In scope SELECT regexpExtract('100-200', '(\\d+)-(\\d+)', 3). (INDEX_OF_POSITIONAL_ARGUMENT_IS_OUT_OF_RANGE) (version 24.3.12.76.altinitystable) (from [::1]:57066) (comment: 02562_regexp_extract.sql) (in query: select regexpExtract('100-200', '(\\d+)-(\\d+)', 3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, String const&, String&&, unsigned int&&) @ 0x00000000213c68f8 4. DB::(anonymous namespace)::FunctionRegexpExtract::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000213c54db 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:47.054584 [ 14973 ] {5f3dc10f-8576-4239-9960-d335b9bba778} TCPHandler: Code: 353. DB::Exception: Index value 3 for regexp pattern `(\d+)-(\d+)` in function regexpExtract is out-of-range, should be in [0, 3): In scope SELECT regexpExtract('100-200', '(\\d+)-(\\d+)', 3). (INDEX_OF_POSITIONAL_ARGUMENT_IS_OUT_OF_RANGE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, String const&, String&&, unsigned int&&) @ 0x00000000213c68f8 4. DB::(anonymous namespace)::FunctionRegexpExtract::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000213c54db 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:47.056792 [ 14973 ] {25ea7662-1cb3-4cdf-ac4c-ea1efe0ee023} executeQuery: Code: 353. DB::Exception: Index value -1 for regexp pattern `(\d+)-(\d+)` in function regexpExtract is out-of-range, should be in [0, 3): In scope SELECT regexpExtract('100-200', '(\\d+)-(\\d+)', -1). (INDEX_OF_POSITIONAL_ARGUMENT_IS_OUT_OF_RANGE) (version 24.3.12.76.altinitystable) (from [::1]:57066) (comment: 02562_regexp_extract.sql) (in query: select regexpExtract('100-200', '(\\d+)-(\\d+)', -1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, String const&, String&&, unsigned int&&) @ 0x00000000213c68f8 4. DB::(anonymous namespace)::FunctionRegexpExtract::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000213c54db 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:47.056903 [ 14973 ] {25ea7662-1cb3-4cdf-ac4c-ea1efe0ee023} TCPHandler: Code: 353. DB::Exception: Index value -1 for regexp pattern `(\d+)-(\d+)` in function regexpExtract is out-of-range, should be in [0, 3): In scope SELECT regexpExtract('100-200', '(\\d+)-(\\d+)', -1). (INDEX_OF_POSITIONAL_ARGUMENT_IS_OUT_OF_RANGE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, String const&, String&&, unsigned int&&) @ 0x00000000213c68f8 4. DB::(anonymous namespace)::FunctionRegexpExtract::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000213c54db 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:47.060559 [ 14973 ] {5efb9176-91c3-4bce-a44b-3f87e8f1ffb9} executeQuery: Code: 353. DB::Exception: Index value 1 for regexp pattern `\d+-\d+` in function regexpExtract is out-of-range, should be in [0, 1): In scope SELECT regexpExtract('100-200', '\\d+-\\d+', 1). (INDEX_OF_POSITIONAL_ARGUMENT_IS_OUT_OF_RANGE) (version 24.3.12.76.altinitystable) (from [::1]:57066) (comment: 02562_regexp_extract.sql) (in query: select regexpExtract('100-200', '\\d+-\\d+', 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, String const&, String&&, unsigned int&&) @ 0x00000000213c68f8 4. DB::(anonymous namespace)::FunctionRegexpExtract::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000213c54db 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:47.060761 [ 14973 ] {5efb9176-91c3-4bce-a44b-3f87e8f1ffb9} TCPHandler: Code: 353. DB::Exception: Index value 1 for regexp pattern `\d+-\d+` in function regexpExtract is out-of-range, should be in [0, 1): In scope SELECT regexpExtract('100-200', '\\d+-\\d+', 1). (INDEX_OF_POSITIONAL_ARGUMENT_IS_OUT_OF_RANGE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, String const&, String&&, unsigned int&&) @ 0x00000000213c68f8 4. DB::(anonymous namespace)::FunctionRegexpExtract::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000213c54db 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:09:47.279378 [ 14973 ] {5dc822c1-c414-4ffd-afd2-2760272ac092} executeQuery: Code: 475. DB::Exception: Incompatible types of WITH FILL expression values with column type Date. (INVALID_WITH_FILL_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:57156) (comment: 02561_with_fill_date_datetime_incompatible.sql) (in query: SELECT today() AS a ORDER BY a ASC WITH FILL FROM now() - toIntervalMonth(1) TO now() + toIntervalDay(1) STEP 82600;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:0: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000033ebc086 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], bool const&>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9cac 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9a03 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000033eb8b8f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002f3e3b2e 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f3e38c1 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033eb7db8 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033edaab5 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:47.279635 [ 14973 ] {5dc822c1-c414-4ffd-afd2-2760272ac092} TCPHandler: Code: 475. DB::Exception: Incompatible types of WITH FILL expression values with column type Date. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:0: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000033ebc086 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], bool const&>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9cac 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9a03 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000033eb8b8f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002f3e3b2e 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f3e38c1 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033eb7db8 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033edaab5 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:47.558762 [ 14973 ] {7fe814cc-0d1c-4349-a00f-294838d05b9a} executeQuery: Code: 69. DB::Exception: Cannot convert value '-3': it cannot be represented as UInt128. (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:57190) (comment: 02560_with_fill_int256_int.sql) (in query: SELECT (number * 2)::UInt128 FROM numbers(10) ORDER BY 1 ASC WITH FILL FROM -3 TO 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169ad02 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:0: DB::tryConvertFields(DB::FillColumnDescription&, std::shared_ptr const&) @ 0x0000000033ebe4eb 6. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:226: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000033ebb366 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], bool const&>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9cac 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9a03 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000033eb8b8f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002f3e3b2e 11. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f3e38c1 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033eb7db8 13. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033edaab5 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:47.558976 [ 14973 ] {7fe814cc-0d1c-4349-a00f-294838d05b9a} TCPHandler: Code: 69. DB::Exception: Cannot convert value '-3': it cannot be represented as UInt128. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169ad02 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:0: DB::tryConvertFields(DB::FillColumnDescription&, std::shared_ptr const&) @ 0x0000000033ebe4eb 6. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:226: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000033ebb366 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], bool const&>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9cac 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9a03 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000033eb8b8f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002f3e3b2e 11. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f3e38c1 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033eb7db8 13. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033edaab5 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:47.562272 [ 14973 ] {6e9118c4-7b79-496d-a937-105ff933eb7d} executeQuery: Code: 69. DB::Exception: Cannot convert value '-3': it cannot be represented as UInt256. (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:57190) (comment: 02560_with_fill_int256_int.sql) (in query: SELECT (number * 2)::UInt256 FROM numbers(10) ORDER BY 1 ASC WITH FILL FROM -3 TO 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169ad02 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:0: DB::tryConvertFields(DB::FillColumnDescription&, std::shared_ptr const&) @ 0x0000000033ebe4eb 6. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:226: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000033ebb366 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], bool const&>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9cac 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9a03 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000033eb8b8f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002f3e3b2e 11. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f3e38c1 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033eb7db8 13. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033edaab5 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:47.562382 [ 14973 ] {6e9118c4-7b79-496d-a937-105ff933eb7d} TCPHandler: Code: 69. DB::Exception: Cannot convert value '-3': it cannot be represented as UInt256. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169ad02 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:0: DB::tryConvertFields(DB::FillColumnDescription&, std::shared_ptr const&) @ 0x0000000033ebe4eb 6. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:226: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000033ebb366 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], bool const&>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9cac 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9a03 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000033eb8b8f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002f3e3b2e 11. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f3e38c1 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033eb7db8 13. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033edaab5 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:48.130728 [ 14973 ] {def293c3-239c-44fc-b443-6f6c936cb1f2} executeQuery: Code: 59. DB::Exception: Illegal type UInt16 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.3.12.76.altinitystable) (from [::1]:57266) (comment: 02559_multiple_read_steps_in_prewhere.sql) (in query: SELECT cast(id1 as UInt16) AS cond1 FROM test_02559 PREWHERE cond1 LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/FilterDescription.cpp:0: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000031fde918 5. ./src/Storages/MergeTree/MergeTreeRangeReader.h:71: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x0000000032e013de 6. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000032dfbc02 7. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1067: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df64b3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:164: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000032e04f6f 9. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000033f8b134 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:139: DB::MergeTreeSelectProcessor::read() @ 0x0000000032de396f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:0: DB::MergeTreeSource::tryGenerate() @ 0x0000000033fb1d35 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 18. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:48.130974 [ 14973 ] {def293c3-239c-44fc-b443-6f6c936cb1f2} TCPHandler: Code: 59. DB::Exception: Illegal type UInt16 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/FilterDescription.cpp:0: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000031fde918 5. ./src/Storages/MergeTree/MergeTreeRangeReader.h:71: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x0000000032e013de 6. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000032dfbc02 7. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1067: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df64b3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:164: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000032e04f6f 9. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000033f8b134 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:139: DB::MergeTreeSelectProcessor::read() @ 0x0000000032de396f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:0: DB::MergeTreeSource::tryGenerate() @ 0x0000000033fb1d35 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 18. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:48.446199 [ 14973 ] {6ef059f5-3861-45ad-84fb-c6b4e31c1b95} executeQuery: Code: 53. DB::Exception: Incompatible types of subcolumn 'k1': Array(Int8) and Int8. (TYPE_MISMATCH) (version 24.3.12.76.altinitystable) (from [::1]:57376) (comment: 02553_type_json_attach_partition.sql) (in query: ALTER TABLE t_json_attach_partition ATTACH PARTITION tuple();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x00000000187c28c3 4. ./build_docker/./src/DataTypes/ObjectUtils.cpp:0: DB::getLeastCommonTypeForDynamicColumnsImpl(std::shared_ptr const&, std::vector, std::allocator>> const&, bool) @ 0x000000002f564172 5. ./build_docker/./src/DataTypes/ObjectUtils.cpp:457: DB::getLeastCommonTypeForDynamicColumns(std::shared_ptr const&, std::vector, std::allocator>> const&, bool) @ 0x000000002f561d80 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3803: DB::MergeTreeData::checkPartDynamicColumns(std::shared_ptr&, DB::DataPartsLock&) const @ 0x0000000032b53176 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3885: DB::MergeTreeData::renameTempPartAndReplaceImpl(std::shared_ptr&, DB::MergeTreeData::Transaction&, DB::DataPartsLock&, std::vector, std::allocator>>*) @ 0x0000000032b57775 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::MergeTreeData::renameTempPartAndAdd(std::shared_ptr&, DB::MergeTreeData::Transaction&, DB::DataPartsLock&) @ 0x0000000032b58d4d 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:2051: DB::StorageMergeTree::attachPartition(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x00000000330b81ef 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032b8121a 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307959bb 12. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:48.446390 [ 14973 ] {6ef059f5-3861-45ad-84fb-c6b4e31c1b95} TCPHandler: Code: 53. DB::Exception: Incompatible types of subcolumn 'k1': Array(Int8) and Int8. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x00000000187c28c3 4. ./build_docker/./src/DataTypes/ObjectUtils.cpp:0: DB::getLeastCommonTypeForDynamicColumnsImpl(std::shared_ptr const&, std::vector, std::allocator>> const&, bool) @ 0x000000002f564172 5. ./build_docker/./src/DataTypes/ObjectUtils.cpp:457: DB::getLeastCommonTypeForDynamicColumns(std::shared_ptr const&, std::vector, std::allocator>> const&, bool) @ 0x000000002f561d80 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3803: DB::MergeTreeData::checkPartDynamicColumns(std::shared_ptr&, DB::DataPartsLock&) const @ 0x0000000032b53176 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3885: DB::MergeTreeData::renameTempPartAndReplaceImpl(std::shared_ptr&, DB::MergeTreeData::Transaction&, DB::DataPartsLock&, std::vector, std::allocator>>*) @ 0x0000000032b57775 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::MergeTreeData::renameTempPartAndAdd(std::shared_ptr&, DB::MergeTreeData::Transaction&, DB::DataPartsLock&) @ 0x0000000032b58d4d 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:2051: DB::StorageMergeTree::attachPartition(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x00000000330b81ef 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032b8121a 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307959bb 12. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:48.596086 [ 14974 ] {64a7acfa-9e58-4fce-ae16-132e4bfc82a5} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_iypkkw9o.src (8fc2bd2d-ef13-4e08-b3a7-c99addbe8fb3), because some tables depend on it: test_iypkkw9o.mv. (HAVE_DEPENDENT_OBJECTS) (version 24.3.12.76.altinitystable) (from [::1]:57404) (comment: 02552_check_referential_table_dependencies.sql) (in query: -- Can't drop because of referential dependencies DROP TABLE src;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000002fda7392 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1456: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9b344 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9ba54 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000307f634b 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:103: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000307f3e26 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000307f29e2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:48.596206 [ 14974 ] {64a7acfa-9e58-4fce-ae16-132e4bfc82a5} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_iypkkw9o.src (8fc2bd2d-ef13-4e08-b3a7-c99addbe8fb3), because some tables depend on it: test_iypkkw9o.mv. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000002fda7392 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1456: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9b344 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9ba54 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000307f634b 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:103: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000307f3e26 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000307f29e2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:48.597589 [ 14974 ] {818df9c6-7298-41a0-8706-cda1938399b4} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_iypkkw9o.dst (c563f14a-4c18-4036-a4de-1f6bb5160c85), because some tables depend on it: test_iypkkw9o.mv. (HAVE_DEPENDENT_OBJECTS) (version 24.3.12.76.altinitystable) (from [::1]:57404) (comment: 02552_check_referential_table_dependencies.sql) (in query: DROP TABLE dst;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000002fda7392 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1456: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9b344 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9ba54 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000307f634b 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:103: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000307f3e26 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000307f29e2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:48.597691 [ 14974 ] {818df9c6-7298-41a0-8706-cda1938399b4} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_iypkkw9o.dst (c563f14a-4c18-4036-a4de-1f6bb5160c85), because some tables depend on it: test_iypkkw9o.mv. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000002fda7392 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1456: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9b344 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9ba54 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000307f634b 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:103: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000307f3e26 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000307f29e2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:49.028207 [ 5753 ] {8f6a002e-695f-4c96-9072-ff0efc52e9a2} executeQuery: Code: 43. DB::Exception: Function transform has signature: transform(T, Array(T), Array(U), U) -> U; or transform(T, Array(T), Array(T)) -> T; where T and U are types.: In scope SELECT transform(number, [1], [NULL]) FROM system.numbers LIMIT 1. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:57434) (comment: 02542_transform_old.sql) (in query: SELECT transform(number, [1], [null]) FROM system.numbers LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000021b460ea 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:49.028506 [ 5753 ] {8f6a002e-695f-4c96-9072-ff0efc52e9a2} TCPHandler: Code: 43. DB::Exception: Function transform has signature: transform(T, Array(T), Array(U), U) -> U; or transform(T, Array(T), Array(T)) -> T; where T and U are types.: In scope SELECT transform(number, [1], [NULL]) FROM system.numbers LIMIT 1. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000021b460ea 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:49.104072 [ 14974 ] {9021bbe7-dd6c-44b3-a566-dd0ff75a0878} executeQuery: Code: 36. DB::Exception: Unexpected type Decimal(38, 3) in function 'transform': In scope SELECT transform(-9223372036854775807, [-1], [toDecimal32(1024, 3)]) FROM system.numbers LIMIT 7. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44550) (comment: 02542_transform_new.sql) (in query: SELECT transform(-9223372036854775807, [-1], [toDecimal32(1024, 3)]) FROM system.numbers LIMIT 7;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x0000000021c33288 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000021b45887 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:49.105301 [ 14974 ] {9021bbe7-dd6c-44b3-a566-dd0ff75a0878} TCPHandler: Code: 36. DB::Exception: Unexpected type Decimal(38, 3) in function 'transform': In scope SELECT transform(-9223372036854775807, [-1], [toDecimal32(1024, 3)]) FROM system.numbers LIMIT 7. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x0000000021c33288 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000021b45887 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:49.108594 [ 14974 ] {f703d25a-fb53-4f64-81ed-16d4b5680766} executeQuery: Code: 36. DB::Exception: Unexpected type Decimal(38, 2) in function 'transform': In scope SELECT [NULL, NULL, NULL, NULL], transform(number, [2147483648], [toDecimal32(1, 2)]) AS x FROM numbers(257) WHERE materialize(10). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44550) (comment: 02542_transform_new.sql) (in query: SELECT [NULL, NULL, NULL, NULL], transform(number, [2147483648], [toDecimal32(1, 2)]) AS x FROM numbers(257) WHERE materialize(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x0000000021c33288 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000021b45887 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:49.108797 [ 14974 ] {f703d25a-fb53-4f64-81ed-16d4b5680766} TCPHandler: Code: 36. DB::Exception: Unexpected type Decimal(38, 2) in function 'transform': In scope SELECT [NULL, NULL, NULL, NULL], transform(number, [2147483648], [toDecimal32(1, 2)]) AS x FROM numbers(257) WHERE materialize(10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x0000000021c33288 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000021b45887 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:49.111231 [ 14974 ] {60f4b456-4ac4-40c6-b9b6-35ebe4f035bc} executeQuery: Code: 36. DB::Exception: Unexpected type Decimal(38, 2) in function 'transform': In scope SELECT transform(-2147483649, [1], [toDecimal32(1, 2)]) GROUP BY [1] WITH TOTALS. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44550) (comment: 02542_transform_new.sql) (in query: SELECT transform(-2147483649, [1], [toDecimal32(1, 2)]) GROUP BY [1] WITH TOTALS;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x0000000021c33288 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000021b45887 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:49.111382 [ 14974 ] {60f4b456-4ac4-40c6-b9b6-35ebe4f035bc} TCPHandler: Code: 36. DB::Exception: Unexpected type Decimal(38, 2) in function 'transform': In scope SELECT transform(-2147483649, [1], [toDecimal32(1, 2)]) GROUP BY [1] WITH TOTALS. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x0000000021c33288 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000021b45887 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:49.277196 [ 3522 ] {5c9b70d9-61c8-4626-b36c-8848bfa554d0} executeQuery: Code: 48. DB::Exception: first element of the key tuple is not UInt64: In scope SELECT sipHash128ReferenceKeyed((0, 0), '1'). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:57414) (comment: 02552_siphash128_reference.sql) (in query: select sipHash128ReferenceKeyed((0, 0), '1');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x000000001889911d 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018a401bd 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018883f13 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018a3fee7 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:09:49.277415 [ 3522 ] {5c9b70d9-61c8-4626-b36c-8848bfa554d0} TCPHandler: Code: 48. DB::Exception: first element of the key tuple is not UInt64: In scope SELECT sipHash128ReferenceKeyed((0, 0), '1'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x000000001889911d 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018a401bd 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018883f13 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018a3fee7 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:09:49.306979 [ 3522 ] {4df75d5e-e39e-4d16-b8c6-ca50c1c7c005} executeQuery: Code: 48. DB::Exception: key must be a tuple: In scope SELECT sipHash128ReferenceKeyed(toUInt64(0), '1'). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:57414) (comment: 02552_siphash128_reference.sql) (in query: select sipHash128ReferenceKeyed(toUInt64(0), '1');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000018898f9c 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018a401bd 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018883f13 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018a3fee7 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:09:49.307226 [ 3522 ] {4df75d5e-e39e-4d16-b8c6-ca50c1c7c005} TCPHandler: Code: 48. DB::Exception: key must be a tuple: In scope SELECT sipHash128ReferenceKeyed(toUInt64(0), '1'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000018898f9c 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018a401bd 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018883f13 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018a3fee7 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:09:49.923772 [ 10241 ] {c18979f4-d17b-4770-bac9-d1ed286b030f} executeQuery: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44742) (comment: 02540_duplicate_primary_key.sql) (in query: CREATE TABLE test (`coverage` DateTime, `haunt` Nullable(Float32) CODEC(Gorilla, ZSTD(1)), `sail` Nullable(Float32) CODEC(Gorilla, ZSTD(1)), `empowerment_turnstile` UInt8, `empowerment_haversack` Nullable(Int16), `empowerment_function` Nullable(Int16), `empowerment_guidance` Nullable(Int32), `empowerment_high` Nullable(Int32), `trading_id` Nullable(Int32), `guidance` Nullable(Int32), `empowerment_rawhide` Int32, `memo` Nullable(Int16), `oeuvre` Nullable(Int16), `bun` Nullable(Int16), `tramp` String, `anthropology_total` Nullable(Float32), `situation_name` String, `timing` Nullable(String), `NAME_cockroach` String, `NAME_toe` String, `business_error_methane` FixedString(110), `business_instrumentation_methane` FixedString(15), `market` UInt8, `crew_memo` Nullable(Int16), `crew_oeuvre` Nullable(Int16), `crew_fortnight` Nullable(Int16), `princess_memo` Nullable(Int16), `princess_oeuvre` Nullable(Int16), `princess_fortnight` Nullable(Int16), `emerald` Nullable(Float32), `cannon_crate` Nullable(String), `thinking` String, `SectorMen` String, `rage_name` Nullable(String), `DevelopmentalLigandName` String, `chard_heavy_quadrant` UInt64, `poster_effective` Nullable(String), PROJECTION chrysalis_trapezium_ham (SELECT empowerment_turnstile, toStartOfInterval(coverage, toIntervalMonth(1)), toStartOfWeek(coverage, 10), toStartOfInterval(coverage, toIntervalDay(1)), NAME_toe, NAME_cockroach, situation_name, memo, oeuvre, crew_memo, crew_oeuvre, bun, sum(multiIf(crew_memo IS NULL, 0, 1)), sum(multiIf(crew_oeuvre IS NULL, 0, 1)), sum(multiIf(crew_fortnight IS NULL, 0, 1)), max(toStartOfInterval(coverage, toIntervalDay(1))), max(CAST(CAST(toStartOfInterval(coverage, toIntervalDay(1)), 'Nullable(DATE)'), 'Nullable(TIMESTAMP)')), min(toStartOfInterval(coverage, toIntervalDay(1))), min(CAST(CAST(toStartOfInterval(coverage, toIntervalDay(1)), 'Nullable(DATE)'), 'Nullable(TIMESTAMP)')), count(), sum(1) GROUP BY empowerment_turnstile, toStartOfInterval(coverage, toIntervalMonth(1)), toStartOfWeek(coverage, 10), toStartOfInterval(coverage, toIntervalDay(1)), empowerment_turnstile, toStartOfInterval(coverage, toIntervalMonth(1)), toStartOfWeek(coverage, 10), toStartOfInterval(coverage, toIntervalDay(1)), NAME_toe, NAME_cockroach, situation_name, memo, oeuvre, crew_memo, crew_oeuvre, bun)) ENGINE = MergeTree PARTITION BY toYYYYMM(coverage) ORDER BY (coverage, situation_name, NAME_toe, NAME_cockroach) SETTINGS index_granularity = 6377, min_bytes_for_wide_part = 1030348047, ratio_of_defaults_for_sparse_serialization = 0.7074437141418457, replace_long_file_name_to_hash = true, max_file_name_length = 22, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 129826016, compact_parts_max_granules_to_buffer = 126, compact_parts_merge_max_bytes_to_prefetch_part = 30610657, merge_max_block_size = 12699, old_parts_lifetime = 30., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 11963372, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 23791, primary_key_compress_block_size = 57820), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:204: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x0000000032af24bd 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:583: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032aef78e 6. ./contrib/llvm-project/libcxx/include/__hash_table:1116: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af0d85 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 13. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:49.924101 [ 10241 ] {c18979f4-d17b-4770-bac9-d1ed286b030f} TCPHandler: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:204: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x0000000032af24bd 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:583: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032aef78e 6. ./contrib/llvm-project/libcxx/include/__hash_table:1116: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af0d85 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 13. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:50.656757 [ 11298 ] {12aa9734-6b9c-4b7c-af47-66a19a37ac02} ConnectionPoolWithFailover: There is no table `test_20wxpu49`.`underlying` on server: localhost:9000 2025.03.05 21:09:50.676334 [ 3522 ] {12aa9734-6b9c-4b7c-af47-66a19a37ac02} executeQuery: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_20wxpu49`.`underlying` on server: localhost:9000 : While sending /var/lib/clickhouse/store/e87/e8776bc0-0767-439b-bc13-87fde3864f9e/shard1_replica1/1.bin. (ALL_CONNECTION_TRIES_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:44874) (comment: 02537_distributed_loosing_files_after_exception.gen.sql) (in query: SYSTEM FLUSH DISTRIBUTED dist;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000326ba9ec 4. ./src/Common/PoolWithFailoverBase.h:0: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x00000000332a91ad 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:223: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000332a45d2 6. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:170: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000332a4e02 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x000000003290e3d2 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:377: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x0000000032906db9 9. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000032906b09 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e722c80 11. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000295508e1 12. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 13. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:50.676550 [ 3522 ] {12aa9734-6b9c-4b7c-af47-66a19a37ac02} TCPHandler: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_20wxpu49`.`underlying` on server: localhost:9000 : While sending /var/lib/clickhouse/store/e87/e8776bc0-0767-439b-bc13-87fde3864f9e/shard1_replica1/1.bin. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000326ba9ec 4. ./src/Common/PoolWithFailoverBase.h:0: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x00000000332a91ad 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:223: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000332a45d2 6. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:170: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000332a4e02 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x000000003290e3d2 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:377: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x0000000032906db9 9. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000032906b09 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e722c80 11. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000295508e1 12. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 13. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:50.679667 [ 11427 ] {a7b6bae3-5a65-4157-b2d4-476a6dea877d} ConnectionPoolWithFailover: There is no table `test_20wxpu49`.`underlying` on server: localhost:9000 2025.03.05 21:09:50.696297 [ 3522 ] {a7b6bae3-5a65-4157-b2d4-476a6dea877d} executeQuery: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_20wxpu49`.`underlying` on server: localhost:9000 : While sending /var/lib/clickhouse/store/e87/e8776bc0-0767-439b-bc13-87fde3864f9e/shard1_replica1/1.bin. (ALL_CONNECTION_TRIES_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:44874) (comment: 02537_distributed_loosing_files_after_exception.gen.sql) (in query: -- check the second since after using queue it may got lost from it SYSTEM FLUSH DISTRIBUTED dist;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000326ba9ec 4. ./src/Common/PoolWithFailoverBase.h:0: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x00000000332a91ad 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:223: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000332a45d2 6. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:170: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000332a4e02 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x000000003290e3d2 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:0: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x0000000032906d57 9. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000032906b09 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e722c80 11. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000295508e1 12. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 13. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:50.696597 [ 3522 ] {a7b6bae3-5a65-4157-b2d4-476a6dea877d} TCPHandler: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_20wxpu49`.`underlying` on server: localhost:9000 : While sending /var/lib/clickhouse/store/e87/e8776bc0-0767-439b-bc13-87fde3864f9e/shard1_replica1/1.bin. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000326ba9ec 4. ./src/Common/PoolWithFailoverBase.h:0: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x00000000332a91ad 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:223: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000332a45d2 6. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:170: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000332a4e02 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x000000003290e3d2 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:0: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x0000000032906d57 9. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000032906b09 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e722c80 11. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000295508e1 12. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 13. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:50.750700 [ 6332 ] {623ca453-8565-4057-bb60-6d1531799bc7} ConnectionPoolWithFailover: There is no table `test_20wxpu49`.`underlying` on server: localhost:9000 2025.03.05 21:09:50.763880 [ 3522 ] {623ca453-8565-4057-bb60-6d1531799bc7} executeQuery: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_20wxpu49`.`underlying` on server: localhost:9000 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/d79/d79ab647-e096-47ce-aba7-9f7fd83b3f0f/shard1_replica1/2.bin. (ALL_CONNECTION_TRIES_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:44874) (comment: 02537_distributed_loosing_files_after_exception.gen.sql) (in query: SYSTEM FLUSH DISTRIBUTED dist;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000326ba9ec 4. ./src/Common/PoolWithFailoverBase.h:0: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x00000000332a91ad 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:223: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000332a45d2 6. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:170: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000332a4e02 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003291e05e 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:119: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&) @ 0x000000003291ac41 9. ./contrib/llvm-project/libcxx/include/__hash_table:340: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(DB::SettingsChanges const&) @ 0x000000003290ce40 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:380: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x0000000032906cde 11. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000032906b09 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e722c80 13. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000295508e1 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:50.764084 [ 3522 ] {623ca453-8565-4057-bb60-6d1531799bc7} TCPHandler: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_20wxpu49`.`underlying` on server: localhost:9000 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/d79/d79ab647-e096-47ce-aba7-9f7fd83b3f0f/shard1_replica1/2.bin. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000326ba9ec 4. ./src/Common/PoolWithFailoverBase.h:0: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x00000000332a91ad 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:223: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000332a45d2 6. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:170: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000332a4e02 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003291e05e 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:119: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&) @ 0x000000003291ac41 9. ./contrib/llvm-project/libcxx/include/__hash_table:340: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(DB::SettingsChanges const&) @ 0x000000003290ce40 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:380: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x0000000032906cde 11. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000032906b09 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e722c80 13. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000295508e1 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:50.766490 [ 1673 ] {4872281f-d540-4d30-a13f-64807f904ca2} ConnectionPoolWithFailover: There is no table `test_20wxpu49`.`underlying` on server: localhost:9000 2025.03.05 21:09:50.779308 [ 3522 ] {4872281f-d540-4d30-a13f-64807f904ca2} executeQuery: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_20wxpu49`.`underlying` on server: localhost:9000 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/d79/d79ab647-e096-47ce-aba7-9f7fd83b3f0f/shard1_replica1//2.bin. (ALL_CONNECTION_TRIES_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:44874) (comment: 02537_distributed_loosing_files_after_exception.gen.sql) (in query: -- check the second since after using queue it may got lost from it SYSTEM FLUSH DISTRIBUTED dist;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000326ba9ec 4. ./src/Common/PoolWithFailoverBase.h:0: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x00000000332a91ad 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:223: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000332a45d2 6. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:170: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000332a4e02 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003291e05e 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:119: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&) @ 0x000000003291ac41 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:0: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(DB::SettingsChanges const&) @ 0x0000000032909f50 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:380: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x0000000032906cde 11. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000032906b09 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e722c80 13. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000295508e1 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:50.779470 [ 3522 ] {4872281f-d540-4d30-a13f-64807f904ca2} TCPHandler: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_20wxpu49`.`underlying` on server: localhost:9000 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/d79/d79ab647-e096-47ce-aba7-9f7fd83b3f0f/shard1_replica1//2.bin. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000326ba9ec 4. ./src/Common/PoolWithFailoverBase.h:0: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x00000000332a91ad 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:223: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000332a45d2 6. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:170: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000332a4e02 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003291e05e 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:119: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&) @ 0x000000003291ac41 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:0: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(DB::SettingsChanges const&) @ 0x0000000032909f50 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:380: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x0000000032906cde 11. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000032906b09 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e722c80 13. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000295508e1 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:50.789155 [ 11434 ] {e9b325c8-82ec-4866-b889-8b791255b4e4} test_20wxpu49.dist.DistributedInsertQueue.default: File /var/lib/clickhouse/store/d79/d79ab647-e096-47ce-aba7-9f7fd83b3f0f/shard1_replica1/2.bin does not exists, likely due to current_batch.txt processing 2025.03.05 21:09:51.179634 [ 3522 ] {bfe87e5c-bfe5-4e66-878d-f9c8ff73533a} executeQuery: Code: 69. DB::Exception: Length of the pattern argument in function replaceAll must be greater than 0.: while executing 'FUNCTION replaceAll(__table1.haystack :: 3, __table1.needle :: 0, 'x'_String :: 2) -> replaceAll(__table1.haystack, __table1.needle, 'x'_String) String : 1'. (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:44944) (comment: 02536_replace_with_nonconst_needle_and_replacement.sql) (in query: -- needle: non-const, replacement: const SELECT replaceAll(haystack, needle, 'x') FROM test_tab;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceAll>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214cdc18 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.179933 [ 3522 ] {bfe87e5c-bfe5-4e66-878d-f9c8ff73533a} TCPHandler: Code: 69. DB::Exception: Length of the pattern argument in function replaceAll must be greater than 0.: while executing 'FUNCTION replaceAll(__table1.haystack :: 3, __table1.needle :: 0, 'x'_String :: 2) -> replaceAll(__table1.haystack, __table1.needle, 'x'_String) String : 1'. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceAll>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214cdc18 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.201444 [ 3522 ] {bb9f3b23-a2fc-4121-8014-9e4a2adbde58} executeQuery: Code: 69. DB::Exception: Length of the pattern argument in function replaceOne must be greater than 0.: while executing 'FUNCTION replaceOne(__table1.haystack :: 3, __table1.needle :: 0, 'x'_String :: 2) -> replaceOne(__table1.haystack, __table1.needle, 'x'_String) String : 1'. (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:44944) (comment: 02536_replace_with_nonconst_needle_and_replacement.sql) (in query: SELECT replaceOne(haystack, needle, 'x') FROM test_tab;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceOne>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214d4618 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.201676 [ 3522 ] {bb9f3b23-a2fc-4121-8014-9e4a2adbde58} TCPHandler: Code: 69. DB::Exception: Length of the pattern argument in function replaceOne must be greater than 0.: while executing 'FUNCTION replaceOne(__table1.haystack :: 3, __table1.needle :: 0, 'x'_String :: 2) -> replaceOne(__table1.haystack, __table1.needle, 'x'_String) String : 1'. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceOne>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214d4618 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.223432 [ 3522 ] {07404be5-9ef1-4185-8a54-fc7eb406745d} executeQuery: Code: 69. DB::Exception: Length of the pattern argument in function replaceRegexpAll must be greater than 0.: while executing 'FUNCTION replaceRegexpAll(__table1.haystack :: 3, __table1.needle :: 0, 'x'_String :: 2) -> replaceRegexpAll(__table1.haystack, __table1.needle, 'x'_String) String : 1'. (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:44944) (comment: 02536_replace_with_nonconst_needle_and_replacement.sql) (in query: SELECT replaceRegexpAll(haystack, needle, 'x') FROM test_tab;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceRegexpAll>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214da005 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.223695 [ 3522 ] {07404be5-9ef1-4185-8a54-fc7eb406745d} TCPHandler: Code: 69. DB::Exception: Length of the pattern argument in function replaceRegexpAll must be greater than 0.: while executing 'FUNCTION replaceRegexpAll(__table1.haystack :: 3, __table1.needle :: 0, 'x'_String :: 2) -> replaceRegexpAll(__table1.haystack, __table1.needle, 'x'_String) String : 1'. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceRegexpAll>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214da005 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.246872 [ 3522 ] {f503c56b-25fd-433c-89b2-78b9ebcbf0c1} executeQuery: Code: 69. DB::Exception: Length of the pattern argument in function replaceRegexpOne must be greater than 0.: while executing 'FUNCTION replaceRegexpOne(__table1.haystack :: 3, __table1.needle :: 0, 'x'_String :: 2) -> replaceRegexpOne(__table1.haystack, __table1.needle, 'x'_String) String : 1'. (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:44944) (comment: 02536_replace_with_nonconst_needle_and_replacement.sql) (in query: SELECT replaceRegexpOne(haystack, needle, 'x') FROM test_tab;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceRegexpOne>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214e13a5 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.247154 [ 3522 ] {f503c56b-25fd-433c-89b2-78b9ebcbf0c1} TCPHandler: Code: 69. DB::Exception: Length of the pattern argument in function replaceRegexpOne must be greater than 0.: while executing 'FUNCTION replaceRegexpOne(__table1.haystack :: 3, __table1.needle :: 0, 'x'_String :: 2) -> replaceRegexpOne(__table1.haystack, __table1.needle, 'x'_String) String : 1'. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceRegexpOne>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214e13a5 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.279275 [ 3522 ] {47474c43-739f-4987-a0bc-1e30f2ad6015} executeQuery: Code: 69. DB::Exception: Length of the pattern argument in function replaceAll must be greater than 0. (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:44944) (comment: 02536_replace_with_nonconst_needle_and_replacement.sql) (in query: -- needle: const, replacement: non-const SELECT replaceAll(haystack, '', replacement) FROM test_tab;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceAll>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214ce984 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.279470 [ 3522 ] {47474c43-739f-4987-a0bc-1e30f2ad6015} TCPHandler: Code: 69. DB::Exception: Length of the pattern argument in function replaceAll must be greater than 0. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceAll>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214ce984 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.310937 [ 3522 ] {3d7db01f-a90a-4e00-83eb-bd9a66a51f20} executeQuery: Code: 69. DB::Exception: Length of the pattern argument in function replaceOne must be greater than 0. (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:44944) (comment: 02536_replace_with_nonconst_needle_and_replacement.sql) (in query: SELECT replaceOne(haystack, '', replacement) FROM test_tab;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceOne>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214d5364 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.311183 [ 3522 ] {3d7db01f-a90a-4e00-83eb-bd9a66a51f20} TCPHandler: Code: 69. DB::Exception: Length of the pattern argument in function replaceOne must be greater than 0. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceOne>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214d5364 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.340202 [ 3522 ] {3b7df71b-8acc-44af-8c5f-e51aa5efe91f} executeQuery: Code: 69. DB::Exception: Length of the pattern argument in function replaceRegexpAll must be greater than 0. (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:44944) (comment: 02536_replace_with_nonconst_needle_and_replacement.sql) (in query: SELECT replaceRegexpAll(haystack, '', replacement) FROM test_tab;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceRegexpAll>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214dacaa 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.340502 [ 3522 ] {3b7df71b-8acc-44af-8c5f-e51aa5efe91f} TCPHandler: Code: 69. DB::Exception: Length of the pattern argument in function replaceRegexpAll must be greater than 0. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceRegexpAll>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214dacaa 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.370878 [ 3522 ] {aea70aa7-daec-469d-bbfd-26d77042ff6c} executeQuery: Code: 69. DB::Exception: Length of the pattern argument in function replaceRegexpOne must be greater than 0. (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:44944) (comment: 02536_replace_with_nonconst_needle_and_replacement.sql) (in query: SELECT replaceRegexpOne(haystack, '', replacement) FROM test_tab;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceRegexpOne>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214e204a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.371127 [ 3522 ] {aea70aa7-daec-469d-bbfd-26d77042ff6c} TCPHandler: Code: 69. DB::Exception: Length of the pattern argument in function replaceRegexpOne must be greater than 0. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceRegexpOne>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214e204a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.393278 [ 3522 ] {84600f6e-7c7b-4a67-9be5-044ff84d06b8} executeQuery: Code: 69. DB::Exception: Length of the pattern argument in function replaceAll must be greater than 0.: while executing 'FUNCTION replaceAll(__table1.haystack :: 3, __table1.needle :: 0, __table1.replacement :: 1) -> replaceAll(__table1.haystack, __table1.needle, __table1.replacement) String : 2'. (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:44944) (comment: 02536_replace_with_nonconst_needle_and_replacement.sql) (in query: -- needle: non-const, replacement: non-const SELECT replaceAll(haystack, needle, replacement) FROM test_tab;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceAll>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214ce024 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.393495 [ 3522 ] {84600f6e-7c7b-4a67-9be5-044ff84d06b8} TCPHandler: Code: 69. DB::Exception: Length of the pattern argument in function replaceAll must be greater than 0.: while executing 'FUNCTION replaceAll(__table1.haystack :: 3, __table1.needle :: 0, __table1.replacement :: 1) -> replaceAll(__table1.haystack, __table1.needle, __table1.replacement) String : 2'. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceAll>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214ce024 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.413196 [ 3522 ] {36a671f1-2ef0-47a0-92df-a4da4dac3a1f} executeQuery: Code: 69. DB::Exception: Length of the pattern argument in function replaceOne must be greater than 0.: while executing 'FUNCTION replaceOne(__table1.haystack :: 3, __table1.needle :: 0, __table1.replacement :: 1) -> replaceOne(__table1.haystack, __table1.needle, __table1.replacement) String : 2'. (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:44944) (comment: 02536_replace_with_nonconst_needle_and_replacement.sql) (in query: SELECT replaceOne(haystack, needle, replacement) FROM test_tab;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceOne>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214d49b8 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.413410 [ 3522 ] {36a671f1-2ef0-47a0-92df-a4da4dac3a1f} TCPHandler: Code: 69. DB::Exception: Length of the pattern argument in function replaceOne must be greater than 0.: while executing 'FUNCTION replaceOne(__table1.haystack :: 3, __table1.needle :: 0, __table1.replacement :: 1) -> replaceOne(__table1.haystack, __table1.needle, __table1.replacement) String : 2'. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceOne>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214d49b8 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.433533 [ 3522 ] {8a4dfaf7-c9c4-4865-89e5-51aa6ecb6085} executeQuery: Code: 69. DB::Exception: Length of the pattern argument in function replaceRegexpAll must be greater than 0.: while executing 'FUNCTION replaceRegexpAll(__table1.haystack :: 3, __table1.needle :: 0, __table1.replacement :: 1) -> replaceRegexpAll(__table1.haystack, __table1.needle, __table1.replacement) String : 2'. (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:44944) (comment: 02536_replace_with_nonconst_needle_and_replacement.sql) (in query: SELECT replaceRegexpAll(haystack, needle, replacement) FROM test_tab;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceRegexpAll>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214da304 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.433767 [ 3522 ] {8a4dfaf7-c9c4-4865-89e5-51aa6ecb6085} TCPHandler: Code: 69. DB::Exception: Length of the pattern argument in function replaceRegexpAll must be greater than 0.: while executing 'FUNCTION replaceRegexpAll(__table1.haystack :: 3, __table1.needle :: 0, __table1.replacement :: 1) -> replaceRegexpAll(__table1.haystack, __table1.needle, __table1.replacement) String : 2'. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceRegexpAll>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214da304 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.453381 [ 3522 ] {dff178fb-f5d4-4b18-b1fe-a11d535831ff} executeQuery: Code: 69. DB::Exception: Length of the pattern argument in function replaceRegexpOne must be greater than 0.: while executing 'FUNCTION replaceRegexpOne(__table1.haystack :: 3, __table1.needle :: 0, __table1.replacement :: 1) -> replaceRegexpOne(__table1.haystack, __table1.needle, __table1.replacement) String : 2'. (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:44944) (comment: 02536_replace_with_nonconst_needle_and_replacement.sql) (in query: SELECT replaceRegexpOne(haystack, needle, replacement) FROM test_tab;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceRegexpOne>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214e16a4 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:51.453615 [ 3522 ] {dff178fb-f5d4-4b18-b1fe-a11d535831ff} TCPHandler: Code: 69. DB::Exception: Length of the pattern argument in function replaceRegexpOne must be greater than 0.: while executing 'FUNCTION replaceRegexpOne(__table1.haystack :: 3, __table1.needle :: 0, __table1.replacement :: 1) -> replaceRegexpOne(__table1.haystack, __table1.needle, __table1.replacement) String : 2'. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceRegexpOne>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000214e16a4 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:52.164035 [ 14920 ] {test_blhr5lyl_test_02585_query_to_kill_id_1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:56486) (comment: 02585_query_status_deadlock.sh) (in query: select * from remote('127.0.0.2', 'system.numbers_mt') where number in (select * from tmp);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Connection::sendExternalTablesData(std::vector>, std::allocator>>>&) @ 0x0000000033288523 9. ./build_docker/./src/Client/HedgedConnections.cpp:115: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&)::$_0::operator()(DB::HedgedConnections::ReplicaState&) const @ 0x00000000332babd5 10. ./build_docker/./src/Client/HedgedConnections.cpp:120: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&) @ 0x00000000332ba4de 11. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:855: DB::RemoteQueryExecutor::sendExternalTables() @ 0x000000002f430af4 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:0: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002f42ea01 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44c5ae 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 17. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:09:52.164430 [ 14920 ] {test_blhr5lyl_test_02585_query_to_kill_id_1} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Connection::sendExternalTablesData(std::vector>, std::allocator>>>&) @ 0x0000000033288523 9. ./build_docker/./src/Client/HedgedConnections.cpp:115: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&)::$_0::operator()(DB::HedgedConnections::ReplicaState&) const @ 0x00000000332babd5 10. ./build_docker/./src/Client/HedgedConnections.cpp:120: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&) @ 0x00000000332ba4de 11. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:855: DB::RemoteQueryExecutor::sendExternalTables() @ 0x000000002f430af4 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:0: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002f42ea01 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44c5ae 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 17. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:09:52.299013 [ 1658 ] {6d512c84-2a35-4faa-9308-2af6e0d8c0aa} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:45820) (comment: 02585_query_status_deadlock.sh) (in query: SELECT `__table1`.`number` AS `number` FROM `system`.`numbers_mt` AS `__table1` WHERE `__table1`.`number` IN (SELECT `__table1`.`number` AS `number` FROM `tmp` AS `__table1`)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Server/TCPHandler.cpp:836: DB::TCPHandler::readData() @ 0x00000000334a990e 5. ./build_docker/./src/Server/TCPHandler.cpp:426: void std::__function::__policy_invoker)>::__call_impl)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x00000000334c2d01 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function)>::operator()(std::shared_ptr) const @ 0x000000002fca6931 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:837: ? @ 0x000000002fc87c64 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f7dbc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:52.299469 [ 1658 ] {6d512c84-2a35-4faa-9308-2af6e0d8c0aa} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Server/TCPHandler.cpp:836: DB::TCPHandler::readData() @ 0x00000000334a990e 5. ./build_docker/./src/Server/TCPHandler.cpp:426: void std::__function::__policy_invoker)>::__call_impl)>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x00000000334c2d01 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function)>::operator()(std::shared_ptr) const @ 0x000000002fca6931 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:837: ? @ 0x000000002fc87c64 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f7dbc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:52.299717 [ 1658 ] {6d512c84-2a35-4faa-9308-2af6e0d8c0aa} TCPHandler: Client has gone away. 2025.03.05 21:09:53.169196 [ 3522 ] {43066e28-580e-4ca6-a7eb-b7598161e754} executeQuery: Code: 182. DB::Exception: Table expression test_ntfd7r8k.merge1 AS __table1 does not support column __table1.Val in PREWHERE. In query SELECT Val FROM merge1 PREWHERE (Val = 65536) OR (Val = 2). (ILLEGAL_PREWHERE) (version 24.3.12.76.altinitystable) (from [::1]:45250) (comment: 02527_storage_merge_prewhere_different_type.sql) (in query: SELECT Val FROM merge1 PREWHERE Val = 65536 OR Val = 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000310389cf 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000310343c1 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008f36 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:53.169411 [ 3522 ] {43066e28-580e-4ca6-a7eb-b7598161e754} TCPHandler: Code: 182. DB::Exception: Table expression test_ntfd7r8k.merge1 AS __table1 does not support column __table1.Val in PREWHERE. In query SELECT Val FROM merge1 PREWHERE (Val = 65536) OR (Val = 2). (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000310389cf 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000310343c1 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008f36 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:53.381108 [ 14973 ] {a8d3fa18-158f-460d-a8eb-392ee620c436} executeQuery: Code: 48. DB::Exception: first element of the key tuple is not UInt64: In scope SELECT sipHash64Keyed((0, 0), '1'). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:45166) (comment: 02534_keyed_siphash.sql) (in query: select sipHash64Keyed((0, 0), '1');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x000000001889911d 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000188ee806 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018883f13 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000188ee547 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:09:53.381262 [ 14973 ] {a8d3fa18-158f-460d-a8eb-392ee620c436} TCPHandler: Code: 48. DB::Exception: first element of the key tuple is not UInt64: In scope SELECT sipHash64Keyed((0, 0), '1'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x000000001889911d 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000188ee806 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018883f13 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000188ee547 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:09:53.412873 [ 14973 ] {974d719c-687b-4029-93e2-ec3de922949a} executeQuery: Code: 48. DB::Exception: first element of the key tuple is not UInt64: In scope SELECT sipHash128Keyed((0, 0), '1'). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:45166) (comment: 02534_keyed_siphash.sql) (in query: select sipHash128Keyed((0, 0), '1');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x000000001889911d 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001899779d 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018883f13 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000189974c7 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:09:53.413116 [ 14973 ] {974d719c-687b-4029-93e2-ec3de922949a} TCPHandler: Code: 48. DB::Exception: first element of the key tuple is not UInt64: In scope SELECT sipHash128Keyed((0, 0), '1'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x000000001889911d 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001899779d 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018883f13 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000189974c7 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:09:53.443972 [ 14973 ] {590a8698-2f64-43ad-9b84-d29cc67111da} executeQuery: Code: 48. DB::Exception: key must be a tuple: In scope SELECT sipHash64Keyed(toUInt64(0), '1'). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:45166) (comment: 02534_keyed_siphash.sql) (in query: select sipHash64Keyed(toUInt64(0), '1');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000018898f9c 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000188ee806 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018883f13 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000188ee547 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:09:53.444219 [ 14973 ] {590a8698-2f64-43ad-9b84-d29cc67111da} TCPHandler: Code: 48. DB::Exception: key must be a tuple: In scope SELECT sipHash64Keyed(toUInt64(0), '1'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000018898f9c 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000188ee806 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018883f13 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000188ee547 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:09:53.477709 [ 14973 ] {bdda7b85-0c65-42bd-8b28-6c9ad424932b} executeQuery: Code: 48. DB::Exception: key must be a tuple: In scope SELECT sipHash128Keyed(toUInt64(0), '1'). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:45166) (comment: 02534_keyed_siphash.sql) (in query: select sipHash128Keyed(toUInt64(0), '1');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000018898f9c 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001899779d 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018883f13 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000189974c7 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:09:53.478033 [ 14973 ] {bdda7b85-0c65-42bd-8b28-6c9ad424932b} TCPHandler: Code: 48. DB::Exception: key must be a tuple: In scope SELECT sipHash128Keyed(toUInt64(0), '1'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000018898f9c 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001899779d 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018883f13 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000189974c7 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:09:53.723297 [ 14973 ] {3d52400b-3631-4a65-92c4-d19d99cd1668} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(UInt16) in case if value is NULL: In scope SELECT [(255, 1048575)], sipHash128ReferenceKeyed((toUInt64(2147483646), toUInt64(9223372036854775807)), ([(NULL, 100), (NULL, NULL), (1024, 10)], toUInt64(2), toUInt64(1024)), ''), hex(sipHash128ReferenceKeyed((-9223372036854775807, 1.), '-1', NULL)), ('', toUInt64(65535), [(9223372036854775807, 9223372036854775806)], toUInt64(65536)), arrayJoin((NULL, 65537, 255), [(NULL, NULL)]) GROUP BY tupleElement((NULL, NULL, NULL, -1), toUInt64(2), 2) = NULL. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:45166) (comment: 02534_keyed_siphash.sql) (in query: SELECT [(255, 1048575)], sipHash128ReferenceKeyed((toUInt64(2147483646), toUInt64(9223372036854775807)), ([(NULL, 100), (NULL, NULL), (1024, 10)], toUInt64(2), toUInt64(1024)), ''), hex(sipHash128ReferenceKeyed((-9223372036854775807, 1.), '-1', NULL)), ('', toUInt64(65535), [(9223372036854775807, 9223372036854775806)], toUInt64(65536)), arrayJoin((NULL, 65537, 255), [(NULL, NULL)]) GROUP BY tupleElement((NULL, NULL, NULL, -1), toUInt64(2), 2) = NULL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/ColumnNullable.cpp:0: DB::ColumnNullable::getDataAt(unsigned long) const @ 0x0000000031b58ef4 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeGeneric(DB::impl::SipHashKeyColumns const&, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x0000000018a4fa5c 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x0000000018a41295 7. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x0000000018a40ae3 8. void DB::TargetSpecific::Default::FunctionAnyHash::executeArray(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x0000000018a4eeb3 9. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x0000000018a41295 10. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x0000000018a40ae3 11. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018a40376 12. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018883f13 13. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018a3fee7 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 15. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 18. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 20. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 22. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 25. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:09:53.723552 [ 14973 ] {3d52400b-3631-4a65-92c4-d19d99cd1668} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(UInt16) in case if value is NULL: In scope SELECT [(255, 1048575)], sipHash128ReferenceKeyed((toUInt64(2147483646), toUInt64(9223372036854775807)), ([(NULL, 100), (NULL, NULL), (1024, 10)], toUInt64(2), toUInt64(1024)), ''), hex(sipHash128ReferenceKeyed((-9223372036854775807, 1.), '-1', NULL)), ('', toUInt64(65535), [(9223372036854775807, 9223372036854775806)], toUInt64(65536)), arrayJoin((NULL, 65537, 255), [(NULL, NULL)]) GROUP BY tupleElement((NULL, NULL, NULL, -1), toUInt64(2), 2) = NULL. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/ColumnNullable.cpp:0: DB::ColumnNullable::getDataAt(unsigned long) const @ 0x0000000031b58ef4 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeGeneric(DB::impl::SipHashKeyColumns const&, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x0000000018a4fa5c 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x0000000018a41295 7. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x0000000018a40ae3 8. void DB::TargetSpecific::Default::FunctionAnyHash::executeArray(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x0000000018a4eeb3 9. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x0000000018a41295 10. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x0000000018a40ae3 11. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018a40376 12. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018883f13 13. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018a3fee7 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 15. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 18. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 20. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 22. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 25. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:09:54.177491 [ 730 ] {141cb8d9-fb88-4891-98ef-89ba57b0a2ff} executeQuery: Code: 43. DB::Exception: First argument of function 'arrayShuffle' must be array: In scope SELECT arrayShuffle(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:45346) (comment: 02523_array_shuffle.sql) (in query: SELECT arrayShuffle(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000023dc0432 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:54.177691 [ 730 ] {141cb8d9-fb88-4891-98ef-89ba57b0a2ff} TCPHandler: Code: 43. DB::Exception: First argument of function 'arrayShuffle' must be array: In scope SELECT arrayShuffle(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000023dc0432 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:54.206587 [ 730 ] {98da245e-79ef-473c-be01-a8f9c90640b6} executeQuery: Code: 43. DB::Exception: Illegal type String of arguments of function arrayShuffle (must be UInt or Int): In scope SELECT arrayShuffle([1], 'a'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:45346) (comment: 02523_array_shuffle.sql) (in query: SELECT arrayShuffle([1], 'a');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. auto DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const::'lambda'(auto)::operator()(auto) const @ 0x0000000023dc1721 5. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000023dc01ab 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:54.206777 [ 730 ] {98da245e-79ef-473c-be01-a8f9c90640b6} TCPHandler: Code: 43. DB::Exception: Illegal type String of arguments of function arrayShuffle (must be UInt or Int): In scope SELECT arrayShuffle([1], 'a'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. auto DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const::'lambda'(auto)::operator()(auto) const @ 0x0000000023dc1721 5. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000023dc01ab 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:54.208720 [ 730 ] {713604db-6dac-4994-9c8e-12aca7229f59} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of arguments of function arrayShuffle (must be UInt or Int): In scope SELECT arrayShuffle([1], 1.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:45346) (comment: 02523_array_shuffle.sql) (in query: SELECT arrayShuffle([1], 1.1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. auto DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const::'lambda'(auto)::operator()(auto) const @ 0x0000000023dc1721 5. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000023dc01ab 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:54.208852 [ 730 ] {713604db-6dac-4994-9c8e-12aca7229f59} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of arguments of function arrayShuffle (must be UInt or Int): In scope SELECT arrayShuffle([1], 1.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. auto DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const::'lambda'(auto)::operator()(auto) const @ 0x0000000023dc1721 5. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000023dc01ab 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:54.240583 [ 730 ] {7eff2e93-96b6-4073-95d7-3796d04fa6ad} executeQuery: Code: 42. DB::Exception: Function 'arrayShuffle' needs from 1 to 2 arguments, passed 3.: In scope SELECT arrayShuffle([1], 51966, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:45346) (comment: 02523_array_shuffle.sql) (in query: SELECT arrayShuffle([1], 0xcafe, 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int const&, unsigned long&&) @ 0x0000000023dc1239 4. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000023dc034b 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:54.240772 [ 730 ] {7eff2e93-96b6-4073-95d7-3796d04fa6ad} TCPHandler: Code: 42. DB::Exception: Function 'arrayShuffle' needs from 1 to 2 arguments, passed 3.: In scope SELECT arrayShuffle([1], 51966, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int const&, unsigned long&&) @ 0x0000000023dc1239 4. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000023dc034b 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:54.509935 [ 10241 ] {63d6fb31-7bab-4d72-95a8-794cf282452a} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of 2nd (optional) argument of function toDayOfWeek. Must be constant UInt8 (week mode).: In scope SELECT toDayOfWeek(today(), -1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:45418) (comment: 02521_to_custom_day_of_week.sql) (in query: select toDayOfWeek(today(), -1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x0000000021a12c48 5. DB::FunctionCustomWeekToSomething, DB::ToDayOfWeekImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021a0f66f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:54.510130 [ 10241 ] {63d6fb31-7bab-4d72-95a8-794cf282452a} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of 2nd (optional) argument of function toDayOfWeek. Must be constant UInt8 (week mode).: In scope SELECT toDayOfWeek(today(), -1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x0000000021a12c48 5. DB::FunctionCustomWeekToSomething, DB::ToDayOfWeekImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021a0f66f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:56.433773 [ 14920 ] {164db5a9-0410-4045-8c6e-7a672f6661e7} executeQuery: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types: While executing Remote. (TYPE_MISMATCH) (version 24.3.12.76.altinitystable) (from [::1]:45656) (comment: 02517_wrong_total_structure_crash.sql) (in query: SELECT field1 FROM alias10__fuzz_13 WHERE arrayEnumerateDense(NULL, tuple('0.2147483646'), NULL) GROUP BY field1, arrayEnumerateDense(('0.02', '0.1', '0'), NULL) WITH TOTALS;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000001825a617 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e5b2 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 7. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000018093622 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000031693477 9. ./build_docker/./src/Interpreters/castColumn.cpp:46: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000316929e1 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::adaptBlockStructure(DB::Block const&, DB::Block const&) @ 0x000000002f435319 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x000000002f43255a 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:502: DB::RemoteQueryExecutor::readAsync() @ 0x000000002f433d43 13. ./src/QueryPipeline/RemoteQueryExecutor.h:161: DB::RemoteSource::tryGenerate() @ 0x0000000033cf1215 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:56.450218 [ 14974 ] {f1b948cb-0520-40ca-b386-44d4ffaae573} executeQuery: Code: 36. DB::Exception: StorageExecutable argument "foobar" is invalid query. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:45670) (comment: 02517_executable_pool_bad_input_query.sql) (in query: CREATE TABLE test_table (value String) ENGINE=ExecutablePool('nonexist.py', 'TabSeparated', (foobar));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageExecutable.cpp:0: DB::registerStorageExecutable(DB::StorageFactory&)::$_1::operator()(DB::StorageFactory::Arguments const&, bool) const @ 0x00000000321d2f10 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:56.450273 [ 14920 ] {164db5a9-0410-4045-8c6e-7a672f6661e7} TCPHandler: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types: While executing Remote. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000001825a617 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e5b2 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 7. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000018093622 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000031693477 9. ./build_docker/./src/Interpreters/castColumn.cpp:46: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000316929e1 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::adaptBlockStructure(DB::Block const&, DB::Block const&) @ 0x000000002f435319 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x000000002f43255a 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:502: DB::RemoteQueryExecutor::readAsync() @ 0x000000002f433d43 13. ./src/QueryPipeline/RemoteQueryExecutor.h:161: DB::RemoteSource::tryGenerate() @ 0x0000000033cf1215 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:56.450378 [ 1574 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::1]:37040). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:56.450479 [ 14974 ] {f1b948cb-0520-40ca-b386-44d4ffaae573} TCPHandler: Code: 36. DB::Exception: StorageExecutable argument "foobar" is invalid query. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageExecutable.cpp:0: DB::registerStorageExecutable(DB::StorageFactory&)::$_1::operator()(DB::StorageFactory::Arguments const&, bool) const @ 0x00000000321d2f10 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:56.452339 [ 14974 ] {e21526ba-7e96-4ba4-8922-5ca50ffff92b} executeQuery: Code: 36. DB::Exception: StorageExecutable argument "'(SELECT 1)'" is invalid query. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:45670) (comment: 02517_executable_pool_bad_input_query.sql) (in query: CREATE TABLE test_table (value String) ENGINE=ExecutablePool('nonexist.py', 'TabSeparated', '(SELECT 1)');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageExecutable.cpp:0: DB::registerStorageExecutable(DB::StorageFactory&)::$_1::operator()(DB::StorageFactory::Arguments const&, bool) const @ 0x00000000321d2f10 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:56.452439 [ 14974 ] {e21526ba-7e96-4ba4-8922-5ca50ffff92b} TCPHandler: Code: 36. DB::Exception: StorageExecutable argument "'(SELECT 1)'" is invalid query. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageExecutable.cpp:0: DB::registerStorageExecutable(DB::StorageFactory&)::$_1::operator()(DB::StorageFactory::Arguments const&, bool) const @ 0x00000000321d2f10 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:56.453779 [ 14974 ] {fdb5f7f6-3736-4836-871b-5fd72ccdbf81} executeQuery: Code: 36. DB::Exception: StorageExecutable argument "[1, 2, 3]" is invalid query. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:45670) (comment: 02517_executable_pool_bad_input_query.sql) (in query: CREATE TABLE test_table (value String) ENGINE=ExecutablePool('nonexist.py', 'TabSeparated', [1,2,3]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageExecutable.cpp:0: DB::registerStorageExecutable(DB::StorageFactory&)::$_1::operator()(DB::StorageFactory::Arguments const&, bool) const @ 0x00000000321d2f10 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:56.453873 [ 14974 ] {fdb5f7f6-3736-4836-871b-5fd72ccdbf81} TCPHandler: Code: 36. DB::Exception: StorageExecutable argument "[1, 2, 3]" is invalid query. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageExecutable.cpp:0: DB::registerStorageExecutable(DB::StorageFactory&)::$_1::operator()(DB::StorageFactory::Arguments const&, bool) const @ 0x00000000321d2f10 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:56.464318 [ 14920 ] {ad43e590-ffcf-440f-8c31-0f2218ef263a} executeQuery: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types: While executing Remote. (TYPE_MISMATCH) (version 24.3.12.76.altinitystable) (from [::1]:45656) (comment: 02517_wrong_total_structure_crash.sql) (in query: SELECT x FROM distributed GROUP BY x WITH TOTALS;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000001825a617 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e5b2 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 7. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000018093622 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000031693477 9. ./build_docker/./src/Interpreters/castColumn.cpp:46: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000316929e1 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::adaptBlockStructure(DB::Block const&, DB::Block const&) @ 0x000000002f435319 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x000000002f43255a 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:502: DB::RemoteQueryExecutor::readAsync() @ 0x000000002f433d43 13. ./src/QueryPipeline/RemoteQueryExecutor.h:161: DB::RemoteSource::tryGenerate() @ 0x0000000033cf1215 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:56.464588 [ 14920 ] {ad43e590-ffcf-440f-8c31-0f2218ef263a} TCPHandler: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types: While executing Remote. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000001825a617 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e5b2 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 7. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000018093622 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000031693477 9. ./build_docker/./src/Interpreters/castColumn.cpp:46: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000316929e1 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::adaptBlockStructure(DB::Block const&, DB::Block const&) @ 0x000000002f435319 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x000000002f43255a 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:502: DB::RemoteQueryExecutor::readAsync() @ 0x000000002f433d43 13. ./src/QueryPipeline/RemoteQueryExecutor.h:161: DB::RemoteSource::tryGenerate() @ 0x0000000033cf1215 14. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:56.464783 [ 14973 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::1]:45686). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:09:56.758319 [ 14920 ] {f0a65b34-e497-49b5-9447-99793bde9af7} executeQuery: Code: 36. DB::Exception: Dictionary (`test_dictionary`) not found: while executing 'FUNCTION dictHas('test_dictionary' :: 3, tuple(materialize('Ke\0')) :: 10) -> dictHas('test_dictionary', tuple(materialize('Ke\0'))) UInt8 : 5'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:45710) (comment: 02516_projections_and_context.sql) (in query: SELECT count() FROM test1__fuzz_37 GROUP BY dictHas(NULL, (dictHas(NULL, (('', materialize(NULL)), materialize(NULL))), 'KeyKey')), dictHas('test_dictionary', tuple(materialize('Ke\0'))), tuple(dictHas(NULL, (tuple('Ke\0Ke\0Ke\0Ke\0Ke\0Ke\0\0\0\0Ke\0'), materialize(NULL)))), 'test_dicti\0nary', (('', materialize(NULL)), dictHas(NULL, (dictHas(NULL, tuple(materialize(NULL))), 'KeyKeyKeyKeyKeyKeyKeyKey')), materialize(NULL));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:0: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000030395792 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x000000003039522a 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000018813b2d 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018825086 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 20. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 21. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 22. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:56.758713 [ 14920 ] {f0a65b34-e497-49b5-9447-99793bde9af7} TCPHandler: Code: 36. DB::Exception: Dictionary (`test_dictionary`) not found: while executing 'FUNCTION dictHas('test_dictionary' :: 3, tuple(materialize('Ke\0')) :: 10) -> dictHas('test_dictionary', tuple(materialize('Ke\0'))) UInt8 : 5'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:0: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000030395792 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x000000003039522a 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000018813b2d 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018825086 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 20. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 21. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 22. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:56.764190 [ 14920 ] {0efe2253-0487-40f6-a7da-c84ad9de5501} executeQuery: Code: 36. DB::Exception: Dictionary (`non_existing_dictionary`) not found: while executing 'FUNCTION dictHas('non_existing_dictionary' :: 0, materialize('a') :: 3) -> dictHas('non_existing_dictionary', materialize('a')) UInt8 : 1'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:45710) (comment: 02516_projections_and_context.sql) (in query: SELECT count() FROM test1__fuzz_37 GROUP BY dictHas('non_existing_dictionary', materialize('a'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:0: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000030395792 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x000000003039522a 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000018813b2d 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018825086 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 20. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 21. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 22. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:56.764385 [ 14920 ] {0efe2253-0487-40f6-a7da-c84ad9de5501} TCPHandler: Code: 36. DB::Exception: Dictionary (`non_existing_dictionary`) not found: while executing 'FUNCTION dictHas('non_existing_dictionary' :: 0, materialize('a') :: 3) -> dictHas('non_existing_dictionary', materialize('a')) UInt8 : 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:0: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000030395792 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x000000003039522a 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000018813b2d 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018825086 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 20. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 21. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 22. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:56.775035 [ 14920 ] {394f4de3-a8ef-40a3-96ab-9eeaf2cc39b0} executeQuery: Code: 36. DB::Exception: Dictionary (`test_dictionary`) not found: while executing 'FUNCTION dictHas('test_dictionary'_String :: 0, tuple(materialize('Ke\0'_String)) :: 1) -> dictHas('test_dictionary'_String, tuple(materialize('Ke\0'_String))) UInt8 : 3'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:45710) (comment: 02516_projections_and_context.sql) (in query: SELECT count() FROM test1__fuzz_37 GROUP BY dictHas(NULL, (dictHas(NULL, (('', materialize(NULL)), materialize(NULL))), 'KeyKey')), dictHas('test_dictionary', tuple(materialize('Ke\0'))), tuple(dictHas(NULL, (tuple('Ke\0Ke\0Ke\0Ke\0Ke\0Ke\0\0\0\0Ke\0'), materialize(NULL)))), 'test_dicti\0nary', (('', materialize(NULL)), dictHas(NULL, (dictHas(NULL, tuple(materialize(NULL))), 'KeyKeyKeyKeyKeyKeyKeyKey')), materialize(NULL));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:0: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000030395792 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x000000003039522a 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000018813b2d 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018825086 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 20. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 21. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 22. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:56.775239 [ 14920 ] {394f4de3-a8ef-40a3-96ab-9eeaf2cc39b0} TCPHandler: Code: 36. DB::Exception: Dictionary (`test_dictionary`) not found: while executing 'FUNCTION dictHas('test_dictionary'_String :: 0, tuple(materialize('Ke\0'_String)) :: 1) -> dictHas('test_dictionary'_String, tuple(materialize('Ke\0'_String))) UInt8 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:0: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000030395792 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x000000003039522a 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000018813b2d 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018825086 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 20. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 21. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 22. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:56.781787 [ 14920 ] {36d1492b-0fc6-4143-a1b4-0abb1279a2da} executeQuery: Code: 36. DB::Exception: Dictionary (`non_existing_dictionary`) not found: while executing 'FUNCTION dictHas('non_existing_dictionary'_String :: 0, materialize('a'_String) :: 3) -> dictHas('non_existing_dictionary'_String, materialize('a'_String)) UInt8 : 1'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:45710) (comment: 02516_projections_and_context.sql) (in query: SELECT count() FROM test1__fuzz_37 GROUP BY dictHas('non_existing_dictionary', materialize('a'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:0: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000030395792 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x000000003039522a 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000018813b2d 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018825086 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 20. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 21. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 22. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:56.781983 [ 14920 ] {36d1492b-0fc6-4143-a1b4-0abb1279a2da} TCPHandler: Code: 36. DB::Exception: Dictionary (`non_existing_dictionary`) not found: while executing 'FUNCTION dictHas('non_existing_dictionary'_String :: 0, materialize('a'_String) :: 3) -> dictHas('non_existing_dictionary'_String, materialize('a'_String)) UInt8 : 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:0: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000030395792 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x000000003039522a 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000018813b2d 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018825086 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 20. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 21. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 22. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:57.931504 [ 14974 ] {21ab7d3b-7123-4d8d-b162-4588f2fba4c1} executeQuery: Code: 388. DB::Exception: Cannot OPTIMIZE table: There is an outdated part in a gap between two active parts (all_2_2_0, all_4_4_0) with merge level 1 higher than these active parts have. Cannot select parts for optimization. (CANNOT_ASSIGN_OPTIMIZE) (version 24.3.12.76.altinitystable) (from [::1]:45876) (comment: 02521_merge_over_gap.sh) (in query: OPTIMIZE TABLE table_with_gap FINAL SETTINGS optimize_throw_if_noop=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1604: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000330a4bc1 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:57.931924 [ 14974 ] {21ab7d3b-7123-4d8d-b162-4588f2fba4c1} TCPHandler: Code: 388. DB::Exception: Cannot OPTIMIZE table: There is an outdated part in a gap between two active parts (all_2_2_0, all_4_4_0) with merge level 1 higher than these active parts have. Cannot select parts for optimization. (CANNOT_ASSIGN_OPTIMIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1604: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000330a4bc1 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.718587 [ 14974 ] {0579c3c6-bc90-4ef5-bffd-05128048cbe4} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Object('json')' because experimental Object type is not allowed. Set setting allow_experimental_object_type = 1 in order to allow it: In scope SELECT CAST('{"x" : 1}', 'JSON'). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:45976) (comment: 02513_validate_data_types.sql) (in query: select CAST('{"x" : 1}', 'JSON');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774da3 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:109: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000031773180 6. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.718824 [ 14974 ] {0579c3c6-bc90-4ef5-bffd-05128048cbe4} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Object('json')' because experimental Object type is not allowed. Set setting allow_experimental_object_type = 1 in order to allow it: In scope SELECT CAST('{"x" : 1}', 'JSON'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774da3 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:109: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000031773180 6. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.742179 [ 14974 ] {247eec47-4d16-4212-a79f-0ed94ae7b2ba} executeQuery: Code: 44. DB::Exception: Cannot infer the data structure in JSONAsObject format because experimental Object type is not allowed. Set setting allow_experimental_object_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:45976) (comment: 02513_validate_data_types.sql) (in query: desc file(nonexist.json, JSONAsObject);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:190: DB::JSONAsObjectExternalSchemaReader::JSONAsObjectExternalSchemaReader(DB::FormatSettings const&) @ 0x00000000337bb58e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, DB::FormatSettings const&) @ 0x00000000337be8bc 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::FormatSettings const&, void>(std::allocator const&, DB::FormatSettings const&) @ 0x00000000337be65e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::FormatSettings const&)>::__call_impl (DB::FormatSettings const&)>>(std::__function::__policy_storage const*, DB::FormatSettings const&) @ 0x00000000337bc0e8 8. ./build_docker/./src/Formats/FormatFactory.cpp:0: DB::FormatFactory::getExternalSchemaReader(String const&, std::shared_ptr const&, std::optional const&) const @ 0x00000000334ed9a3 9. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:114: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033512c4b 10. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 11. ./build_docker/./src/Storages/StorageFile.cpp:943: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321dd621 12. ./build_docker/./src/Storages/StorageFile.cpp:956: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321ddfa1 13. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4655ce 14. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 15. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.742417 [ 14974 ] {247eec47-4d16-4212-a79f-0ed94ae7b2ba} TCPHandler: Code: 44. DB::Exception: Cannot infer the data structure in JSONAsObject format because experimental Object type is not allowed. Set setting allow_experimental_object_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:190: DB::JSONAsObjectExternalSchemaReader::JSONAsObjectExternalSchemaReader(DB::FormatSettings const&) @ 0x00000000337bb58e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, DB::FormatSettings const&) @ 0x00000000337be8bc 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::FormatSettings const&, void>(std::allocator const&, DB::FormatSettings const&) @ 0x00000000337be65e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::FormatSettings const&)>::__call_impl (DB::FormatSettings const&)>>(std::__function::__policy_storage const*, DB::FormatSettings const&) @ 0x00000000337bc0e8 8. ./build_docker/./src/Formats/FormatFactory.cpp:0: DB::FormatFactory::getExternalSchemaReader(String const&, std::shared_ptr const&, std::optional const&) const @ 0x00000000334ed9a3 9. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:114: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033512c4b 10. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 11. ./build_docker/./src/Storages/StorageFile.cpp:943: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321dd621 12. ./build_docker/./src/Storages/StorageFile.cpp:956: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321ddfa1 13. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4655ce 14. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 15. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.759752 [ 14974 ] {c1d7b4d3-939e-4ab1-bf9d-f309d6915afb} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Object('json')' because experimental Object type is not allowed. Set setting allow_experimental_object_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:45976) (comment: 02513_validate_data_types.sql) (in query: desc file(nonexist.json, JSONEachRow, 'x JSON');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774da3 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:109: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000031773180 6. ./contrib/llvm-project/libcxx/include/list:400: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x00000000317757d6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e465128 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.760014 [ 14974 ] {c1d7b4d3-939e-4ab1-bf9d-f309d6915afb} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Object('json')' because experimental Object type is not allowed. Set setting allow_experimental_object_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031774da3 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:109: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000031773180 6. ./contrib/llvm-project/libcxx/include/list:400: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x00000000317757d6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e465128 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.795460 [ 14974 ] {efcd2536-c416-4285-8ce3-33e777f46ba6} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(1000000, 'LowCardinality(UInt64)'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.3.12.76.altinitystable) (from [::1]:45976) (comment: 02513_validate_data_types.sql) (in query: select CAST(1000000, 'LowCardinality(UInt64)');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:109: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000031773180 6. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.795741 [ 14974 ] {efcd2536-c416-4285-8ce3-33e777f46ba6} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting.: In scope SELECT CAST(1000000, 'LowCardinality(UInt64)'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:109: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000031773180 6. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.820617 [ 14974 ] {a0713c45-9400-4b8b-83ed-1eb981d4b72d} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 24.3.12.76.altinitystable) (from [::1]:45976) (comment: 02513_validate_data_types.sql) (in query: desc file(nonexist.json, JSONEachRow, 'lc LowCardinality(UInt64)');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:109: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000031773180 6. ./contrib/llvm-project/libcxx/include/list:400: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x00000000317757d6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e465128 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.820939 [ 14974 ] {a0713c45-9400-4b8b-83ed-1eb981d4b72d} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the "allow_suspicious_low_cardinality_types" setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000031775006 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:109: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000031773180 6. ./contrib/llvm-project/libcxx/include/list:400: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x00000000317757d6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e465128 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.858389 [ 14974 ] {dc01ffe2-b6aa-408c-843d-05583f43a973} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('', 'FixedString(1000)'). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:45976) (comment: 02513_validate_data_types.sql) (in query: select CAST('', 'FixedString(1000)');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:109: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000031773180 6. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.858706 [ 14974 ] {dc01ffe2-b6aa-408c-843d-05583f43a973} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('', 'FixedString(1000)'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:109: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000031773180 6. ./build_docker/./src/Functions/CastOverloadResolver.cpp:102: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002e8d23d8 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.874946 [ 14974 ] {d2a9294a-0538-4a2f-b911-c7e8829dd687} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:45976) (comment: 02513_validate_data_types.sql) (in query: desc file(nonexist.json, JSONEachRow, 'fs FixedString(1000)');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:109: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000031773180 6. ./contrib/llvm-project/libcxx/include/list:400: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x00000000317757d6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e465128 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.906546 [ 730 ] {d9a380b6-91c4-461f-9405-8288aefedc3a} executeQuery: Code: 53. DB::Exception: Cannot convert string 2020-03-04 10:20:45 to type Date. (TYPE_MISMATCH) (version 24.3.12.76.altinitystable) (from [::1]:45996) (comment: 02513_date_string_comparison.sql) (in query: SELECT count() FROM datetime_date_table WHERE col_date > '2020-03-04 10:20:45';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169a592 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb7c50a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5cba5 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.906586 [ 14974 ] {d2a9294a-0538-4a2f-b911-c7e8829dd687} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:109: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000031773180 6. ./contrib/llvm-project/libcxx/include/list:400: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x00000000317757d6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e465128 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.906790 [ 730 ] {d9a380b6-91c4-461f-9405-8288aefedc3a} TCPHandler: Code: 53. DB::Exception: Cannot convert string 2020-03-04 10:20:45 to type Date. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169a592 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb7c50a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5cba5 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.918046 [ 730 ] {e382bedb-6d48-4aeb-9978-28953b94b30c} executeQuery: Code: 53. DB::Exception: Cannot convert string 2020-03-04 10:20:45.100 to type Date. (TYPE_MISMATCH) (version 24.3.12.76.altinitystable) (from [::1]:45996) (comment: 02513_date_string_comparison.sql) (in query: SELECT count() FROM datetime_date_table WHERE col_date > '2020-03-04 10:20:45.100';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169a592 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb7c50a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5cba5 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.918153 [ 730 ] {e382bedb-6d48-4aeb-9978-28953b94b30c} TCPHandler: Code: 53. DB::Exception: Cannot convert string 2020-03-04 10:20:45.100 to type Date. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169a592 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb7c50a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5cba5 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.961170 [ 730 ] {1b1d9bf5-3471-4c53-8d20-3b9e4f4522d6} executeQuery: Code: 53. DB::Exception: Cannot convert string 2020-03-04 10:20:45.100 to type DateTime. (TYPE_MISMATCH) (version 24.3.12.76.altinitystable) (from [::1]:45996) (comment: 02513_date_string_comparison.sql) (in query: SELECT count() FROM datetime_date_table WHERE col_datetime > '2020-03-04 10:20:45.100';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169a592 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb7c50a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5cba5 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:58.961367 [ 730 ] {1b1d9bf5-3471-4c53-8d20-3b9e4f4522d6} TCPHandler: Code: 53. DB::Exception: Cannot convert string 2020-03-04 10:20:45.100 to type DateTime. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169a592 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb7c50a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5cba5 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.018779 [ 730 ] {bdd7014a-5a0f-4233-8748-778801c72308} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, Date because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:45996) (comment: 02513_date_string_comparison.sql) (in query: SELECT count() FROM datetime_date_table WHERE col_date_string > '2020-03-04'::Date;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001bb7ef4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9f1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.019173 [ 730 ] {bdd7014a-5a0f-4233-8748-778801c72308} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, Date because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001bb7ef4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9f1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.031114 [ 730 ] {d243186e-b06f-4b0b-b62d-b8fc07f75dae} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, DateTime because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:45996) (comment: 02513_date_string_comparison.sql) (in query: SELECT count() FROM datetime_date_table WHERE col_date_string > '2020-03-04 10:20:45'::DateTime;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001bb7ef4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9f1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.031228 [ 730 ] {d243186e-b06f-4b0b-b62d-b8fc07f75dae} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, DateTime because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001bb7ef4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9f1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.072604 [ 730 ] {23bdd285-cde4-4440-850c-389d45141c3e} executeQuery: Code: 43. DB::Exception: No operation greater between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:45996) (comment: 02513_date_string_comparison.sql) (in query: SELECT count() FROM datetime_date_table WHERE col_date_string > '2020-03-04 10:20:45.100'::DateTime64(3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9b5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 14. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 15. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.072881 [ 730 ] {23bdd285-cde4-4440-850c-389d45141c3e} TCPHandler: Code: 43. DB::Exception: No operation greater between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9b5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 14. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 15. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.086681 [ 730 ] {8428a2c7-d3a3-46d2-947b-8d6744b5a6f7} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, Date because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:45996) (comment: 02513_date_string_comparison.sql) (in query: SELECT count() FROM datetime_date_table WHERE col_datetime_string > '2020-03-04'::Date;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001bb7ef4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9f1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.086805 [ 730 ] {8428a2c7-d3a3-46d2-947b-8d6744b5a6f7} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, Date because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001bb7ef4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9f1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.098000 [ 730 ] {c6e2d256-293d-4209-b65c-b0b02567ea2c} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, DateTime because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:45996) (comment: 02513_date_string_comparison.sql) (in query: SELECT count() FROM datetime_date_table WHERE col_datetime_string > '2020-03-04 10:20:45'::DateTime;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001bb7ef4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9f1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.098132 [ 730 ] {c6e2d256-293d-4209-b65c-b0b02567ea2c} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, DateTime because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001bb7ef4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9f1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.110695 [ 730 ] {49b1fa41-8685-4fbd-9dd7-7720069fc253} executeQuery: Code: 43. DB::Exception: No operation greater between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:45996) (comment: 02513_date_string_comparison.sql) (in query: SELECT count() FROM datetime_date_table WHERE col_datetime_string > '2020-03-04 10:20:45.100'::DateTime64(3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9b5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 14. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 15. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.110899 [ 730 ] {49b1fa41-8685-4fbd-9dd7-7720069fc253} TCPHandler: Code: 43. DB::Exception: No operation greater between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9b5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 14. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 15. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.169192 [ 730 ] {769b50bb-5666-4705-aa7a-03a39beb0c13} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, Date because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:45996) (comment: 02513_date_string_comparison.sql) (in query: SELECT count() FROM datetime_date_table WHERE col_date_lc > '2020-03-04'::Date;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001bb7ef4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9f1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e8413ae 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.169499 [ 730 ] {769b50bb-5666-4705-aa7a-03a39beb0c13} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, Date because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001bb7ef4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9f1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e8413ae 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.184255 [ 730 ] {36008913-ba6c-46ca-ab9a-0077f59361d5} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, DateTime because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:45996) (comment: 02513_date_string_comparison.sql) (in query: SELECT count() FROM datetime_date_table WHERE col_date_lc > '2020-03-04 10:20:45'::DateTime;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001bb7ef4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9f1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e8413ae 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.184384 [ 730 ] {36008913-ba6c-46ca-ab9a-0077f59361d5} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, DateTime because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001bb7ef4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9f1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e8413ae 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.223288 [ 730 ] {380358f1-f10c-42ee-9f24-eb191e16be96} executeQuery: Code: 43. DB::Exception: No operation greater between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:45996) (comment: 02513_date_string_comparison.sql) (in query: SELECT count() FROM datetime_date_table WHERE col_date_lc > '2020-03-04 10:20:45.100'::DateTime64(3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9b5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e8413ae 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 14. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 15. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.223484 [ 730 ] {380358f1-f10c-42ee-9f24-eb191e16be96} TCPHandler: Code: 43. DB::Exception: No operation greater between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9b5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e8413ae 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 14. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 15. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.239719 [ 730 ] {aa7bab52-bdd1-4ab7-8c7b-16a5aa6afa8c} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, Date because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:45996) (comment: 02513_date_string_comparison.sql) (in query: SELECT count() FROM datetime_date_table WHERE col_datetime_lc > '2020-03-04'::Date;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001bb7ef4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9f1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e8413ae 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.239871 [ 730 ] {aa7bab52-bdd1-4ab7-8c7b-16a5aa6afa8c} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, Date because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001bb7ef4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9f1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e8413ae 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.251488 [ 730 ] {3ce3e215-88aa-41e2-b3fe-b4babaee2935} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, DateTime because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:45996) (comment: 02513_date_string_comparison.sql) (in query: SELECT count() FROM datetime_date_table WHERE col_datetime_lc > '2020-03-04 10:20:45'::DateTime;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001bb7ef4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9f1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e8413ae 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.252190 [ 730 ] {3ce3e215-88aa-41e2-b3fe-b4babaee2935} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, DateTime because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001bb7ef4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9f1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e8413ae 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.261176 [ 730 ] {8d856be6-887d-4363-af64-4ce7d667ea33} executeQuery: Code: 43. DB::Exception: No operation greater between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:45996) (comment: 02513_date_string_comparison.sql) (in query: SELECT count() FROM datetime_date_table WHERE col_datetime_lc > '2020-03-04 10:20:45.100'::DateTime64(3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9b5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e8413ae 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 14. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 15. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.261320 [ 730 ] {8d856be6-887d-4363-af64-4ce7d667ea33} TCPHandler: Code: 43. DB::Exception: No operation greater between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bb5d9b5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e8413ae 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 14. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 15. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.485404 [ 730 ] {709761ad-7d19-4669-9b25-4c6328780814} executeQuery: Code: 80. DB::Exception: It's not allowed to specify explicit zookeeper_path and replica_name for ReplicatedMergeTree arguments in Replicated database. If you really want to specify them explicitly, enable setting database_replicated_allow_replicated_engine_arguments. (INCORRECT_QUERY) (version 24.3.12.76.altinitystable) (from [::1]:39868) (comment: 02514_database_replicated_no_arguments_for_rmt.sh) (in query: CREATE TABLE test_4rxmp4qm_db.tab_rmt_fail (`x` UInt32) ENGINE = ReplicatedMergeTree('/clickhouse/tables/02514_database_replicated_no_arguments_for_rmt_test_4rxmp4qm/root/{shard}', '{replica}') ORDER BY x SETTINGS index_granularity = 48728, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 32, min_bytes_for_full_part_storage = 348873837, compact_parts_max_bytes_to_buffer = 236669278, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 17956057, merge_max_block_size = 1639, old_parts_lifetime = 30., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 56, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 19252081, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 62338, primary_key_compress_block_size = 23428), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f785ba7 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:777: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f786779 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1c55 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:09:59.485698 [ 730 ] {709761ad-7d19-4669-9b25-4c6328780814} TCPHandler: Code: 80. DB::Exception: It's not allowed to specify explicit zookeeper_path and replica_name for ReplicatedMergeTree arguments in Replicated database. If you really want to specify them explicitly, enable setting database_replicated_allow_replicated_engine_arguments. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f785ba7 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:777: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f786779 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1c55 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.024455 [ 14974 ] {5e78b8e6-dc93-42c3-95e0-e244a5649303} executeQuery: Code: 36. DB::Exception: Only `Float64` data type is allowed for the value column of GraphiteMergeTree. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:39916) (comment: 02508_bad_graphite.sql) (in query: INSERT INTO test_graphite (key) VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Processors/Merges/Algorithms/GraphiteRollupSortedAlgorithm.cpp:36: DB::GraphiteRollupSortedAlgorithm::GraphiteRollupSortedAlgorithm(DB::Block const&, unsigned long, DB::SortDescription, unsigned long, unsigned long, DB::Graphite::Params, long) @ 0x0000000033d384b1 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::GraphiteRollupSortedAlgorithm* std::construct_at[abi:v15000](DB::GraphiteRollupSortedAlgorithm*, DB::Block&, int&&, DB::SortDescription&, unsigned long&&, int&&, DB::Graphite::Params const&, long&&) @ 0x0000000032edd762 6. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, DB::Block&, int&&, DB::SortDescription&, unsigned long&&, int&&, DB::Graphite::Params const&, long&&) @ 0x0000000032edd0dc 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block&, int, DB::SortDescription&, unsigned long, int, DB::Graphite::Params const&, long, void>(std::allocator const&, DB::Block&, int&&, DB::SortDescription&, unsigned long&&, int&&, DB::Graphite::Params const&, long&&) @ 0x0000000032edce69 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:360: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000032eca9a2 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000032ecc814 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:404: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032ecb650 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:86: DB::MergeTreeSink::consume(DB::Chunk) @ 0x00000000330e0419 12. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 18. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.024725 [ 14974 ] {5e78b8e6-dc93-42c3-95e0-e244a5649303} TCPHandler: Code: 36. DB::Exception: Only `Float64` data type is allowed for the value column of GraphiteMergeTree. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Processors/Merges/Algorithms/GraphiteRollupSortedAlgorithm.cpp:36: DB::GraphiteRollupSortedAlgorithm::GraphiteRollupSortedAlgorithm(DB::Block const&, unsigned long, DB::SortDescription, unsigned long, unsigned long, DB::Graphite::Params, long) @ 0x0000000033d384b1 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::GraphiteRollupSortedAlgorithm* std::construct_at[abi:v15000](DB::GraphiteRollupSortedAlgorithm*, DB::Block&, int&&, DB::SortDescription&, unsigned long&&, int&&, DB::Graphite::Params const&, long&&) @ 0x0000000032edd762 6. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, DB::Block&, int&&, DB::SortDescription&, unsigned long&&, int&&, DB::Graphite::Params const&, long&&) @ 0x0000000032edd0dc 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block&, int, DB::SortDescription&, unsigned long, int, DB::Graphite::Params const&, long, void>(std::allocator const&, DB::Block&, int&&, DB::SortDescription&, unsigned long&&, int&&, DB::Graphite::Params const&, long&&) @ 0x0000000032edce69 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:360: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000032eca9a2 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000032ecc814 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:404: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032ecb650 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:86: DB::MergeTreeSink::consume(DB::Chunk) @ 0x00000000330e0419 12. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 18. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.124566 [ 10241 ] {79ba9db4-288a-432e-ad40-ca4322be8c53} executeQuery: Code: 36. DB::Exception: Cannot load time zone /abc: In scope SELECT toDateTime(0, '/abc'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:39946) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (in query: select toDateTime(0, '/abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000002465a6b8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x0000000024657601 6. ./src/Common/DateLUT.h:62: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002f463950 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:12: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002f463125 8. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, String&&) @ 0x000000001878d39c 9. std::shared_ptr std::allocate_shared[abi:v15000], String, void>(std::allocator const&, String&&) @ 0x000000001878d100 10. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000184d1d83 11. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001849834f 12. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 13. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 14. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:10:00.124857 [ 10241 ] {79ba9db4-288a-432e-ad40-ca4322be8c53} TCPHandler: Code: 36. DB::Exception: Cannot load time zone /abc: In scope SELECT toDateTime(0, '/abc'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000002465a6b8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x0000000024657601 6. ./src/Common/DateLUT.h:62: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002f463950 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:12: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002f463125 8. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, String&&) @ 0x000000001878d39c 9. std::shared_ptr std::allocate_shared[abi:v15000], String, void>(std::allocator const&, String&&) @ 0x000000001878d100 10. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000184d1d83 11. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001849834f 12. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 13. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 14. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:10:00.127188 [ 10241 ] {afffcb0c-ef63-4733-88dc-a83185b74282} executeQuery: Code: 36. DB::Exception: Cannot load time zone ./abc: In scope SELECT toDateTime(0, './abc'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:39946) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (in query: select toDateTime(0, './abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000002465a6b8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x0000000024657601 6. ./src/Common/DateLUT.h:62: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002f463950 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:12: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002f463125 8. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, String&&) @ 0x000000001878d39c 9. std::shared_ptr std::allocate_shared[abi:v15000], String, void>(std::allocator const&, String&&) @ 0x000000001878d100 10. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000184d1d83 11. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001849834f 12. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 13. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 14. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:10:00.127314 [ 10241 ] {afffcb0c-ef63-4733-88dc-a83185b74282} TCPHandler: Code: 36. DB::Exception: Cannot load time zone ./abc: In scope SELECT toDateTime(0, './abc'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000002465a6b8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x0000000024657601 6. ./src/Common/DateLUT.h:62: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002f463950 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:12: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002f463125 8. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, String&&) @ 0x000000001878d39c 9. std::shared_ptr std::allocate_shared[abi:v15000], String, void>(std::allocator const&, String&&) @ 0x000000001878d100 10. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000184d1d83 11. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001849834f 12. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 13. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 14. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:10:00.129790 [ 10241 ] {3277e667-252a-4344-b753-6a2907057dd0} executeQuery: Code: 36. DB::Exception: Cannot load time zone ../abc: In scope SELECT toDateTime(0, '../abc'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:39946) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (in query: select toDateTime(0, '../abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000002465a6b8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x0000000024657601 6. ./src/Common/DateLUT.h:62: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002f463950 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:12: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002f463125 8. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, String&&) @ 0x000000001878d39c 9. std::shared_ptr std::allocate_shared[abi:v15000], String, void>(std::allocator const&, String&&) @ 0x000000001878d100 10. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000184d1d83 11. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001849834f 12. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 13. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 14. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:10:00.129978 [ 10241 ] {3277e667-252a-4344-b753-6a2907057dd0} TCPHandler: Code: 36. DB::Exception: Cannot load time zone ../abc: In scope SELECT toDateTime(0, '../abc'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000002465a6b8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x0000000024657601 6. ./src/Common/DateLUT.h:62: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002f463950 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:12: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002f463125 8. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, String&&) @ 0x000000001878d39c 9. std::shared_ptr std::allocate_shared[abi:v15000], String, void>(std::allocator const&, String&&) @ 0x000000001878d100 10. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000184d1d83 11. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001849834f 12. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 13. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 14. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:10:00.132001 [ 10241 ] {508a6936-4aa3-4c17-b8e1-3fbf2277a643} executeQuery: Code: 36. DB::Exception: Cannot load time zone ~/abc: In scope SELECT toDateTime(0, '~/abc'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:39946) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (in query: select toDateTime(0, '~/abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000002465a6b8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x0000000024657601 6. ./src/Common/DateLUT.h:62: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002f463950 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:12: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002f463125 8. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, String&&) @ 0x000000001878d39c 9. std::shared_ptr std::allocate_shared[abi:v15000], String, void>(std::allocator const&, String&&) @ 0x000000001878d100 10. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000184d1d83 11. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001849834f 12. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 13. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 14. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:10:00.132138 [ 10241 ] {508a6936-4aa3-4c17-b8e1-3fbf2277a643} TCPHandler: Code: 36. DB::Exception: Cannot load time zone ~/abc: In scope SELECT toDateTime(0, '~/abc'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000002465a6b8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x0000000024657601 6. ./src/Common/DateLUT.h:62: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002f463950 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:12: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002f463125 8. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, String&&) @ 0x000000001878d39c 9. std::shared_ptr std::allocate_shared[abi:v15000], String, void>(std::allocator const&, String&&) @ 0x000000001878d100 10. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000184d1d83 11. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001849834f 12. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 13. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 14. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:10:00.134046 [ 10241 ] {14310340-e9b5-4caa-be55-bbd0d2bf6145} executeQuery: Code: 36. DB::Exception: Cannot load time zone abc/../../cba: In scope SELECT toDateTime(0, 'abc/../../cba'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:39946) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (in query: select toDateTime(0, 'abc/../../cba');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000002465a6b8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x0000000024657601 6. ./src/Common/DateLUT.h:62: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002f463950 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:12: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002f463125 8. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, String&&) @ 0x000000001878d39c 9. std::shared_ptr std::allocate_shared[abi:v15000], String, void>(std::allocator const&, String&&) @ 0x000000001878d100 10. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000184d1d83 11. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001849834f 12. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 13. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 14. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:10:00.134181 [ 10241 ] {14310340-e9b5-4caa-be55-bbd0d2bf6145} TCPHandler: Code: 36. DB::Exception: Cannot load time zone abc/../../cba: In scope SELECT toDateTime(0, 'abc/../../cba'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000002465a6b8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x0000000024657601 6. ./src/Common/DateLUT.h:62: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002f463950 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:12: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002f463125 8. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, String&&) @ 0x000000001878d39c 9. std::shared_ptr std::allocate_shared[abi:v15000], String, void>(std::allocator const&, String&&) @ 0x000000001878d100 10. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000184d1d83 11. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001849834f 12. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 13. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 14. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:10:00.450339 [ 11339 ] {eaafdc66-7367-4fa7-ad71-0955641de3b0} ExternalDictionariesLoader: Could not update external dictionary '84573a58-fcb5-4520-aff9-7cf78ae20b69', leaving the previous version: Code: 489. DB::Exception: There are duplicate id 6. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000001904abbb 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x0000000029205b40 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:320: DB::RegExpTreeDictionary::loadData() @ 0x0000000029208114 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:423: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000002920a834 7. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002921336e 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e831b7d 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830dc0 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 14. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 15. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:00.473699 [ 10241 ] {eaafdc66-7367-4fa7-ad71-0955641de3b0} executeQuery: Code: 489. DB::Exception: There are duplicate id 6. (INCORRECT_DICTIONARY_DEFINITION) (version 24.3.12.76.altinitystable) (from [::1]:39966) (comment: 02504_regexp_dictionary_table_source.sql) (in query: SYSTEM RELOAD dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000001904abbb 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x0000000029205b40 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:320: DB::RegExpTreeDictionary::loadData() @ 0x0000000029208114 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:423: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000002920a834 7. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002921336e 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e831b7d 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830dc0 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 14. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 15. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.473699 [ 14974 ] {64c7dcc4-bcfc-4851-9dc5-4291ad356ae3} executeQuery: Code: 36. DB::Exception: Cannot parse ClickHouse version here: a.a: in attempt to set the value of setting 'compatibility' to 'a.a'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:39984) (comment: 02503_bad_compatibility_setting.sql) (in query: set compatibility='a.a';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./src/Core/SettingsChangesHistory.h:35: DB::ClickHouseVersion::ClickHouseVersion(String const&) @ 0x000000002e639b6f 5. ./contrib/llvm-project/libcxx/include/__tree:870: DB::Settings::applyCompatibilitySetting(String const&) @ 0x000000002f1b8879 6. ./build_docker/./src/Core/Settings.cpp:130: DB::Settings::set(std::basic_string_view>, DB::Field const&) @ 0x000000002f1b8544 7. ./build_docker/./src/Interpreters/Context.cpp:2112: DB::Context::setSettingWithLock(std::basic_string_view>, DB::Field const&, std::lock_guard const&) @ 0x000000002fc640ae 8. ./build_docker/./src/Interpreters/Context.cpp:4451: DB::Context::applySettingChangeWithLock(DB::SettingChange const&, std::lock_guard const&) @ 0x000000002fc6415a 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Context::applySettingsChangesWithLock(DB::SettingsChanges const&, std::lock_guard const&) @ 0x000000002fc4f54c 10. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::Context::applySettingsChanges(DB::SettingsChanges const&) @ 0x000000002fc64930 11. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x00000000310cdd81 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.488321 [ 1574 ] {960d7f53-6f9e-42a0-8005-7fa4e2caeb40} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a Values format file. Error: Code: 27. DB::Exception: Cannot parse input: expected ')' at end of stream. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.3.12.76.altinitystable). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.3.12.76.altinitystable) (from [::1]:39992) (comment: 02502_bad_values_schema_inference.sql) (in query: desc format(Values, '(\'abc)');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:279: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351840a 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4f121d 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.488337 [ 14974 ] {64c7dcc4-bcfc-4851-9dc5-4291ad356ae3} TCPHandler: Code: 36. DB::Exception: Cannot parse ClickHouse version here: a.a: in attempt to set the value of setting 'compatibility' to 'a.a'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./src/Core/SettingsChangesHistory.h:35: DB::ClickHouseVersion::ClickHouseVersion(String const&) @ 0x000000002e639b6f 5. ./contrib/llvm-project/libcxx/include/__tree:870: DB::Settings::applyCompatibilitySetting(String const&) @ 0x000000002f1b8879 6. ./build_docker/./src/Core/Settings.cpp:130: DB::Settings::set(std::basic_string_view>, DB::Field const&) @ 0x000000002f1b8544 7. ./build_docker/./src/Interpreters/Context.cpp:2112: DB::Context::setSettingWithLock(std::basic_string_view>, DB::Field const&, std::lock_guard const&) @ 0x000000002fc640ae 8. ./build_docker/./src/Interpreters/Context.cpp:4451: DB::Context::applySettingChangeWithLock(DB::SettingChange const&, std::lock_guard const&) @ 0x000000002fc6415a 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Context::applySettingsChangesWithLock(DB::SettingsChanges const&, std::lock_guard const&) @ 0x000000002fc4f54c 10. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::Context::applySettingsChanges(DB::SettingsChanges const&) @ 0x000000002fc64930 11. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x00000000310cdd81 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.488376 [ 10241 ] {eaafdc66-7367-4fa7-ad71-0955641de3b0} TCPHandler: Code: 489. DB::Exception: There are duplicate id 6. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000001904abbb 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x0000000029205b40 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:320: DB::RegExpTreeDictionary::loadData() @ 0x0000000029208114 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:423: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000002920a834 7. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002921336e 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e831b7d 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830dc0 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 14. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 15. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.488529 [ 1574 ] {960d7f53-6f9e-42a0-8005-7fa4e2caeb40} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a Values format file. Error: Code: 27. DB::Exception: Cannot parse input: expected ')' at end of stream. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.3.12.76.altinitystable). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:279: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351840a 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4f121d 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.522473 [ 6301 ] {e05f5774-0a09-4668-8a42-ac5f5ffd9799} ExternalDictionariesLoader: Could not update external dictionary '84573a58-fcb5-4520-aff9-7cf78ae20b69', leaving the previous version: Code: 489. DB::Exception: Unknown parent id 2 in regexp tree dictionary. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000001904abbb 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:286: DB::RegExpTreeDictionary::initGraph() @ 0x00000000292076e6 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::loadData() @ 0x0000000029208134 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:423: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000002920a834 7. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002921336e 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e831b7d 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830dc0 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 14. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 15. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:00.522913 [ 10241 ] {e05f5774-0a09-4668-8a42-ac5f5ffd9799} executeQuery: Code: 489. DB::Exception: Unknown parent id 2 in regexp tree dictionary. (INCORRECT_DICTIONARY_DEFINITION) (version 24.3.12.76.altinitystable) (from [::1]:39966) (comment: 02504_regexp_dictionary_table_source.sql) (in query: SYSTEM RELOAD dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000001904abbb 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:286: DB::RegExpTreeDictionary::initGraph() @ 0x00000000292076e6 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::loadData() @ 0x0000000029208134 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:423: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000002920a834 7. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002921336e 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e831b7d 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830dc0 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 14. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 15. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.523068 [ 10241 ] {e05f5774-0a09-4668-8a42-ac5f5ffd9799} TCPHandler: Code: 489. DB::Exception: Unknown parent id 2 in regexp tree dictionary. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000001904abbb 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:286: DB::RegExpTreeDictionary::initGraph() @ 0x00000000292076e6 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::loadData() @ 0x0000000029208134 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:423: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000002920a834 7. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002921336e 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e831b7d 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830dc0 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 14. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 15. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.578323 [ 11424 ] {fd1b8c9c-c35d-4399-be7b-305aab1a99dd} ExternalDictionariesLoader: Could not update external dictionary '84573a58-fcb5-4520-aff9-7cf78ae20b69', leaving the previous version: Code: 489. DB::Exception: The regexp tree is cyclical. Please check your config. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:295: DB::RegExpTreeDictionary::initGraph() @ 0x0000000029207908 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::loadData() @ 0x0000000029208134 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:423: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000002920a834 7. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002921336e 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e831b7d 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830dc0 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 14. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 15. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:00.578732 [ 10241 ] {fd1b8c9c-c35d-4399-be7b-305aab1a99dd} executeQuery: Code: 489. DB::Exception: The regexp tree is cyclical. Please check your config. (INCORRECT_DICTIONARY_DEFINITION) (version 24.3.12.76.altinitystable) (from [::1]:39966) (comment: 02504_regexp_dictionary_table_source.sql) (in query: SYSTEM RELOAD dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:295: DB::RegExpTreeDictionary::initGraph() @ 0x0000000029207908 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::loadData() @ 0x0000000029208134 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:423: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000002920a834 7. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002921336e 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e831b7d 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830dc0 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 14. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 15. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.579067 [ 10241 ] {fd1b8c9c-c35d-4399-be7b-305aab1a99dd} TCPHandler: Code: 489. DB::Exception: The regexp tree is cyclical. Please check your config. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:295: DB::RegExpTreeDictionary::initGraph() @ 0x0000000029207908 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::loadData() @ 0x0000000029208134 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:423: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000002920a834 7. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002921336e 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e831b7d 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830dc0 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 14. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 15. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.632490 [ 14974 ] {c8a75da5-a536-4e3a-8f1d-f9f122737e93} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 4.00. (TOO_MANY_ROWS_OR_BYTES) (version 24.3.12.76.altinitystable) (from [::1]:40006) (comment: 02501_limits_on_result_for_view.sql) (in query: -- test SELECT * from 02501_view settings max_result_rows = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:51: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000033b7014d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.653320 [ 11312 ] {5146a3d4-0464-483e-8b78-c55a6da7027d} ExternalDictionariesLoader: Could not update external dictionary '84573a58-fcb5-4520-aff9-7cf78ae20b69', leaving the previous version: Code: 489. DB::Exception: There are no available regular expression. Please check your config. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:324: DB::RegExpTreeDictionary::loadData() @ 0x00000000292096dc 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:423: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000002920a834 6. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002921336e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e831b7d 8. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830dc0 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 10. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 13. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:00.653390 [ 14974 ] {c8a75da5-a536-4e3a-8f1d-f9f122737e93} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 4.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:51: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000033b7014d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.653736 [ 10241 ] {5146a3d4-0464-483e-8b78-c55a6da7027d} executeQuery: Code: 489. DB::Exception: There are no available regular expression. Please check your config. (INCORRECT_DICTIONARY_DEFINITION) (version 24.3.12.76.altinitystable) (from [::1]:39966) (comment: 02504_regexp_dictionary_table_source.sql) (in query: SYSTEM RELOAD dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:324: DB::RegExpTreeDictionary::loadData() @ 0x00000000292096dc 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:423: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000002920a834 6. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002921336e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e831b7d 8. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830dc0 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 10. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 13. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.653923 [ 10241 ] {5146a3d4-0464-483e-8b78-c55a6da7027d} TCPHandler: Code: 489. DB::Exception: There are no available regular expression. Please check your config. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:324: DB::RegExpTreeDictionary::loadData() @ 0x00000000292096dc 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:423: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000002920a834 6. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002921336e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e831b7d 8. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830dc0 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 10. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 13. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.744728 [ 14974 ] {7fb49f9a-04c7-4c3e-ada9-11d42468e71e} executeQuery: Code: 36. DB::Exception: Cannot drop or clear columns 'nes.b, nes.a', because all columns in part 'all_1_1_0' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40016) (comment: 02500_prevent_drop_nested_if_empty_part.sql) (in query: ALTER TABLE 02500_nested DROP COLUMN nes;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x0000000032bed063 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b42655 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.745063 [ 14974 ] {7fb49f9a-04c7-4c3e-ada9-11d42468e71e} TCPHandler: Code: 36. DB::Exception: Cannot drop or clear columns 'nes.b, nes.a', because all columns in part 'all_1_1_0' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x0000000032bed063 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b42655 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.786088 [ 14974 ] {a4d25079-7233-4e66-bde3-bbdc9366540d} executeQuery: Code: 36. DB::Exception: Cannot drop or clear column 'nes', because all columns in part 'all_1_1_0' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40016) (comment: 02500_prevent_drop_nested_if_empty_part.sql) (in query: ALTER TABLE 02500_nested DROP COLUMN nes;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x0000000032bed063 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b42655 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:00.786202 [ 14974 ] {a4d25079-7233-4e66-bde3-bbdc9366540d} TCPHandler: Code: 36. DB::Exception: Cannot drop or clear column 'nes', because all columns in part 'all_1_1_0' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x0000000032bed063 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b42655 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:01.032667 [ 10241 ] {da01dd8a-3781-449d-badf-9e61ad748db8} executeQuery: Code: 36. DB::Exception: Invalid arguments, key_value_delimiter conflicts with pair delimiters: In scope WITH extractKeyValuePairs('not_important', ':', ',:', '\'') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40034) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (in query: -- { echoOff } -- cross parameter validation tests -- should fail because key value delimiter conflicts with pair delimiters WITH extractKeyValuePairs('not_important', ':', ',:', '\'') AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:0: DB::extractKV::ConfigurationFactory::validate(char, char, std::vector>) @ 0x00000000246100bd 5. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:0: DB::extractKV::ConfigurationFactory::createWithoutEscaping(char, char, std::vector>) @ 0x000000002460fd3d 6. ./build_docker/./src/Functions/keyvaluepair/impl/KeyValuePairExtractorBuilder.cpp:0: DB::KeyValuePairExtractorBuilder::buildWithoutEscaping() const @ 0x0000000024610be1 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:0: DB::ExtractKeyValuePairs::getExtractor(DB::ArgumentExtractor::ParsedArguments const&) const @ 0x000000002460d1f8 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca83 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 24. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 27. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 30. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 2025.03.05 21:10:01.071648 [ 10241 ] {da01dd8a-3781-449d-badf-9e61ad748db8} TCPHandler: Code: 36. DB::Exception: Invalid arguments, key_value_delimiter conflicts with pair delimiters: In scope WITH extractKeyValuePairs('not_important', ':', ',:', '\'') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:0: DB::extractKV::ConfigurationFactory::validate(char, char, std::vector>) @ 0x00000000246100bd 5. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:0: DB::extractKV::ConfigurationFactory::createWithoutEscaping(char, char, std::vector>) @ 0x000000002460fd3d 6. ./build_docker/./src/Functions/keyvaluepair/impl/KeyValuePairExtractorBuilder.cpp:0: DB::KeyValuePairExtractorBuilder::buildWithoutEscaping() const @ 0x0000000024610be1 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:0: DB::ExtractKeyValuePairs::getExtractor(DB::ArgumentExtractor::ParsedArguments const&) const @ 0x000000002460d1f8 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca83 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 24. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 27. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 30. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 2025.03.05 21:10:01.071593 [ 14974 ] {8283a69a-ea1f-45c8-89d4-a2a3b439e8b3} executeQuery: Code: 1. DB::Exception: Aggregate function 'count' does not support lambda arguments. (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:40038) (comment: 02499_analyzer_aggregate_function_lambda_crash_fix.sql) (in query: SELECT count((t, x_0, x_1) -> ((key_2, x_0, x_1) IN (NULL, NULL, '0.3'))) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5974: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b7c3d 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:01.072071 [ 14974 ] {8283a69a-ea1f-45c8-89d4-a2a3b439e8b3} TCPHandler: Code: 1. DB::Exception: Aggregate function 'count' does not support lambda arguments. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5974: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b7c3d 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:01.100576 [ 14974 ] {4e3d1448-1fe0-4394-8bdf-3d8d0a97a25c} executeQuery: Code: 1. DB::Exception: Window function 'count' does not support lambda arguments. (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:40038) (comment: 02499_analyzer_aggregate_function_lambda_crash_fix.sql) (in query: SELECT count((t, x_0, x_1) -> ((key_2, x_0, x_1) IN (NULL, NULL, '0.3'))) OVER (PARTITION BY id) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b6889 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:01.137569 [ 10241 ] {f10cf76a-bf77-450b-9038-78c9c0ccefe5} executeQuery: Code: 36. DB::Exception: Control character argument must either be empty or contain exactly 1 character: In scope WITH extractKeyValuePairs('not_important', ':', ',', '\':') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40034) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (in query: -- should fail because key value delimiter conflicts with quoting characters WITH extractKeyValuePairs('not_important', ':', ',', '\':') AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:94: DB::ArgumentExtractor::extractSingleCharacter(DB::ColumnWithTypeAndName const&, String const&) @ 0x0000000024609e67 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::list>) @ 0x00000000246092ea 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x0000000024609139 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca38 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 23. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 26. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 27. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 29. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 30. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 2025.03.05 21:10:01.137628 [ 14974 ] {4e3d1448-1fe0-4394-8bdf-3d8d0a97a25c} TCPHandler: Code: 1. DB::Exception: Window function 'count' does not support lambda arguments. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b6889 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:01.137867 [ 10241 ] {f10cf76a-bf77-450b-9038-78c9c0ccefe5} TCPHandler: Code: 36. DB::Exception: Control character argument must either be empty or contain exactly 1 character: In scope WITH extractKeyValuePairs('not_important', ':', ',', '\':') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:94: DB::ArgumentExtractor::extractSingleCharacter(DB::ColumnWithTypeAndName const&, String const&) @ 0x0000000024609e67 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::list>) @ 0x00000000246092ea 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x0000000024609139 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca38 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 23. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 26. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 27. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 29. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 30. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 2025.03.05 21:10:01.167605 [ 10241 ] {433126c5-63c7-4a21-ba03-3cd893fc3c6f} executeQuery: Code: 36. DB::Exception: Invalid arguments, quoting_character conflicts with pair delimiters: In scope WITH extractKeyValuePairs('not_important', ':', ',', ',') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40034) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (in query: -- should fail because pair delimiters conflicts with quoting characters WITH extractKeyValuePairs('not_important', ':', ',', ',') AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:0: DB::extractKV::ConfigurationFactory::validate(char, char, std::vector>) @ 0x0000000024610119 5. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:0: DB::extractKV::ConfigurationFactory::createWithoutEscaping(char, char, std::vector>) @ 0x000000002460fd3d 6. ./build_docker/./src/Functions/keyvaluepair/impl/KeyValuePairExtractorBuilder.cpp:0: DB::KeyValuePairExtractorBuilder::buildWithoutEscaping() const @ 0x0000000024610be1 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:0: DB::ExtractKeyValuePairs::getExtractor(DB::ArgumentExtractor::ParsedArguments const&) const @ 0x000000002460d1f8 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca83 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 24. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 27. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 30. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 2025.03.05 21:10:01.167899 [ 10241 ] {433126c5-63c7-4a21-ba03-3cd893fc3c6f} TCPHandler: Code: 36. DB::Exception: Invalid arguments, quoting_character conflicts with pair delimiters: In scope WITH extractKeyValuePairs('not_important', ':', ',', ',') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:0: DB::extractKV::ConfigurationFactory::validate(char, char, std::vector>) @ 0x0000000024610119 5. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:0: DB::extractKV::ConfigurationFactory::createWithoutEscaping(char, char, std::vector>) @ 0x000000002460fd3d 6. ./build_docker/./src/Functions/keyvaluepair/impl/KeyValuePairExtractorBuilder.cpp:0: DB::KeyValuePairExtractorBuilder::buildWithoutEscaping() const @ 0x0000000024610be1 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:0: DB::ExtractKeyValuePairs::getExtractor(DB::ArgumentExtractor::ParsedArguments const&) const @ 0x000000002460d1f8 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca83 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 24. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 27. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 30. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 2025.03.05 21:10:01.193834 [ 10241 ] {b0bd56ba-fb9f-4bc0-9ee9-358eca499a82} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument data_column. Must be String.: In scope WITH extractKeyValuePairs([1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:40034) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (in query: -- should fail because data_column argument must be of type String WITH extractKeyValuePairs([1, 2]) AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x000000002460a97b 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x000000002460a340 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::ArgumentExtractor::extractStringColumn(DB::ColumnWithTypeAndName const&, String const&) @ 0x00000000246098aa 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ArgumentExtractor::extract(std::list>) @ 0x00000000246091ff 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x0000000024609139 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca38 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 24. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 27. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 30. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 2025.03.05 21:10:01.194118 [ 10241 ] {b0bd56ba-fb9f-4bc0-9ee9-358eca499a82} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument data_column. Must be String.: In scope WITH extractKeyValuePairs([1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x000000002460a97b 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x000000002460a340 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::ArgumentExtractor::extractStringColumn(DB::ColumnWithTypeAndName const&, String const&) @ 0x00000000246098aa 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ArgumentExtractor::extract(std::list>) @ 0x00000000246091ff 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x0000000024609139 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca38 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 24. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 27. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 30. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 2025.03.05 21:10:01.220122 [ 10241 ] {48488fef-cd0d-432b-a235-a81838aa58fa} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument key_value_delimiter. Must be String.: In scope WITH extractKeyValuePairs('', [1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:40034) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (in query: -- should fail because key_value_delimiter argument must be of type String WITH extractKeyValuePairs('', [1, 2]) AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x000000002460a97b 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x000000002460a340 5. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::ArgumentExtractor::extractSingleCharacter(DB::ColumnWithTypeAndName const&, String const&) @ 0x0000000024609c40 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::list>) @ 0x000000002460924b 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x0000000024609139 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca38 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 24. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 27. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 30. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 2025.03.05 21:10:01.220404 [ 10241 ] {48488fef-cd0d-432b-a235-a81838aa58fa} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument key_value_delimiter. Must be String.: In scope WITH extractKeyValuePairs('', [1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x000000002460a97b 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x000000002460a340 5. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::ArgumentExtractor::extractSingleCharacter(DB::ColumnWithTypeAndName const&, String const&) @ 0x0000000024609c40 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::list>) @ 0x000000002460924b 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x0000000024609139 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca38 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 24. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 27. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 30. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 2025.03.05 21:10:01.246216 [ 10241 ] {ff774478-2dcd-4281-ab8f-eef5a4d61dac} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument pair_delimiters. Must be String.: In scope WITH extractKeyValuePairs('', ':', [1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:40034) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (in query: -- should fail because pair_delimiters argument must be of type String WITH extractKeyValuePairs('', ':', [1, 2]) AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x000000002460a97b 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x000000002460a340 5. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::ArgumentExtractor::extractVector(DB::ColumnWithTypeAndName const&, String const&) @ 0x000000002460a02a 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ArgumentExtractor::extract(std::list>) @ 0x000000002460929e 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x0000000024609139 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca38 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 24. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 27. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 30. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 2025.03.05 21:10:01.246500 [ 10241 ] {ff774478-2dcd-4281-ab8f-eef5a4d61dac} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument pair_delimiters. Must be String.: In scope WITH extractKeyValuePairs('', ':', [1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x000000002460a97b 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x000000002460a340 5. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::ArgumentExtractor::extractVector(DB::ColumnWithTypeAndName const&, String const&) @ 0x000000002460a02a 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ArgumentExtractor::extract(std::list>) @ 0x000000002460929e 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x0000000024609139 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca38 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 24. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 27. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 30. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 2025.03.05 21:10:01.272489 [ 10241 ] {fefbea1d-42f2-4f98-9c61-45db3c32803e} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument quoting_character. Must be String.: In scope WITH extractKeyValuePairs('', ':', ' ', [1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:40034) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (in query: -- should fail because quoting_character argument must be of type String WITH extractKeyValuePairs('', ':', ' ', [1, 2]) AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x000000002460a97b 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x000000002460a340 5. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::ArgumentExtractor::extractSingleCharacter(DB::ColumnWithTypeAndName const&, String const&) @ 0x0000000024609c40 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::list>) @ 0x00000000246092ea 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x0000000024609139 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca38 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 24. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 27. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 30. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 2025.03.05 21:10:01.272748 [ 10241 ] {fefbea1d-42f2-4f98-9c61-45db3c32803e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument quoting_character. Must be String.: In scope WITH extractKeyValuePairs('', ':', ' ', [1, 2]) AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception&, String const&>(int, FormatStringHelperImpl&>::type, std::type_identity::type>, std::shared_ptr&, String const&) @ 0x000000002460a97b 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:123: DB::ArgumentExtractor::validateColumnType(std::shared_ptr, String const&) @ 0x000000002460a340 5. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::ArgumentExtractor::extractSingleCharacter(DB::ColumnWithTypeAndName const&, String const&) @ 0x0000000024609c40 6. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::list>) @ 0x00000000246092ea 7. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x0000000024609139 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca38 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 24. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 27. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 30. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 2025.03.05 21:10:01.297822 [ 10241 ] {d153cdeb-0c43-4aeb-9d5c-2adce7ceb92c} executeQuery: Code: 36. DB::Exception: Invalid arguments, pair delimiters can contain at most 8 characters: In scope WITH extractKeyValuePairs('not_important', ':', '123456789', '\'') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40034) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (in query: -- should fail because pair delimiters can contain at most 8 characters WITH extractKeyValuePairs('not_important', ':', '123456789', '\'') AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int const&) @ 0x000000002461063a 4. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:0: DB::extractKV::ConfigurationFactory::validate(char, char, std::vector>) @ 0x000000002460ffe6 5. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:0: DB::extractKV::ConfigurationFactory::createWithoutEscaping(char, char, std::vector>) @ 0x000000002460fd3d 6. ./build_docker/./src/Functions/keyvaluepair/impl/KeyValuePairExtractorBuilder.cpp:0: DB::KeyValuePairExtractorBuilder::buildWithoutEscaping() const @ 0x0000000024610be1 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:0: DB::ExtractKeyValuePairs::getExtractor(DB::ArgumentExtractor::ParsedArguments const&) const @ 0x000000002460d1f8 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca83 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 24. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 27. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 30. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 2025.03.05 21:10:01.298074 [ 10241 ] {d153cdeb-0c43-4aeb-9d5c-2adce7ceb92c} TCPHandler: Code: 36. DB::Exception: Invalid arguments, pair delimiters can contain at most 8 characters: In scope WITH extractKeyValuePairs('not_important', ':', '123456789', '\'') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int const&) @ 0x000000002461063a 4. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:0: DB::extractKV::ConfigurationFactory::validate(char, char, std::vector>) @ 0x000000002460ffe6 5. ./build_docker/./src/Functions/keyvaluepair/impl/Configuration.cpp:0: DB::extractKV::ConfigurationFactory::createWithoutEscaping(char, char, std::vector>) @ 0x000000002460fd3d 6. ./build_docker/./src/Functions/keyvaluepair/impl/KeyValuePairExtractorBuilder.cpp:0: DB::KeyValuePairExtractorBuilder::buildWithoutEscaping() const @ 0x0000000024610be1 7. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:0: DB::ExtractKeyValuePairs::getExtractor(DB::ArgumentExtractor::ParsedArguments const&) const @ 0x000000002460d1f8 8. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca83 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 24. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 27. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 30. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 2025.03.05 21:10:01.324490 [ 10241 ] {a336e83c-de59-426c-b149-09a88e8a01fb} executeQuery: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope WITH extractKeyValuePairs() AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:40034) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (in query: -- should fail because no argument has been provided WITH extractKeyValuePairs() AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int const&, unsigned long&&) @ 0x000000002460a4e1 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:38: DB::ArgumentExtractor::extract(std::list>) @ 0x00000000246095a7 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x0000000024609139 6. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca38 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 19. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 22. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 25. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 28. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 29. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 30. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 2025.03.05 21:10:01.324729 [ 10241 ] {a336e83c-de59-426c-b149-09a88e8a01fb} TCPHandler: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope WITH extractKeyValuePairs() AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int const&, unsigned long&&) @ 0x000000002460a4e1 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:38: DB::ArgumentExtractor::extract(std::list>) @ 0x00000000246095a7 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x0000000024609139 6. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca38 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 19. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 22. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 25. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 28. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 29. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 30. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 2025.03.05 21:10:01.327012 [ 10241 ] {f3685d7a-ca1f-4a15-a96e-efcffd6730dc} executeQuery: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 5 was provided: In scope WITH extractKeyValuePairs('a', ':', ',', '"', '') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:40034) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (in query: -- should fail because one extra argument / non existent has been provided WITH extractKeyValuePairs('a', ':', ',', '"', '') AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int const&, unsigned long&&) @ 0x000000002460a4e1 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:38: DB::ArgumentExtractor::extract(std::list>) @ 0x00000000246095a7 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x0000000024609139 6. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca38 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 19. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 22. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 25. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 28. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 29. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 30. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 2025.03.05 21:10:01.327127 [ 10241 ] {f3685d7a-ca1f-4a15-a96e-efcffd6730dc} TCPHandler: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 5 was provided: In scope WITH extractKeyValuePairs('a', ':', ',', '"', '') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int const&, unsigned long&&) @ 0x000000002460a4e1 4. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:38: DB::ArgumentExtractor::extract(std::list>) @ 0x00000000246095a7 5. ./build_docker/./src/Functions/keyvaluepair/ArgumentExtractor.cpp:0: DB::ArgumentExtractor::extract(std::vector> const&) @ 0x0000000024609139 6. ./build_docker/./src/Functions/keyvaluepair/extractKeyValuePairs.cpp:103: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460ca38 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 19. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 22. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 25. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 28. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 29. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 30. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 2025.03.05 21:10:01.353870 [ 10241 ] {e9e191b5-4696-4be0-a94e-44aff95933ce} executeQuery: Code: 290. DB::Exception: Number of pairs produced exceeded the limit of 1: In scope WITH extractKeyValuePairs('key1:value1,key2:value2') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:40034) (comment: 02499_extract_key_value_pairs_multiple_input.sql) (in query: WITH extractKeyValuePairs('key1:value1,key2:value2') AS s_map, CAST( arrayMap( (x) -> (x, s_map[x]), arraySort(mapKeys(s_map)) ), 'Map(String,String)' ) AS x SELECT x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000001904abbb 4. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:121: DB::extractKV::StateHandler::NextState DB::CHKeyValuePairExtractor::flushPair(std::basic_string_view> const&, DB::extractKV::NoEscapingStateHandler::StringWriter&, DB::extractKV::NoEscapingStateHandler::StringWriter&, unsigned long&) @ 0x0000000024614a6f 5. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:105: DB::extractKV::StateHandler::NextState DB::CHKeyValuePairExtractor::processState(std::basic_string_view>, DB::extractKV::StateHandler::State, DB::extractKV::NoEscapingStateHandler::StringWriter&, DB::extractKV::NoEscapingStateHandler::StringWriter&, unsigned long&) @ 0x0000000024612dc8 6. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:49: DB::CHKeyValuePairExtractor::extract(std::basic_string_view>, COW::mutable_ptr&, COW::mutable_ptr&) @ 0x00000000246121fa 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::ExtractKeyValuePairs::extract(COW::immutable_ptr, std::shared_ptr) const @ 0x000000002460d4e6 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460cb79 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 24. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 27. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 30. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 2025.03.05 21:10:01.354066 [ 10241 ] {e9e191b5-4696-4be0-a94e-44aff95933ce} TCPHandler: Code: 290. DB::Exception: Number of pairs produced exceeded the limit of 1: In scope WITH extractKeyValuePairs('key1:value1,key2:value2') AS s_map, CAST(arrayMap(x -> (x, s_map[x]), arraySort(mapKeys(s_map))), 'Map(String,String)') AS x SELECT x. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000001904abbb 4. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:121: DB::extractKV::StateHandler::NextState DB::CHKeyValuePairExtractor::flushPair(std::basic_string_view> const&, DB::extractKV::NoEscapingStateHandler::StringWriter&, DB::extractKV::NoEscapingStateHandler::StringWriter&, unsigned long&) @ 0x0000000024614a6f 5. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:105: DB::extractKV::StateHandler::NextState DB::CHKeyValuePairExtractor::processState(std::basic_string_view>, DB::extractKV::StateHandler::State, DB::extractKV::NoEscapingStateHandler::StringWriter&, DB::extractKV::NoEscapingStateHandler::StringWriter&, unsigned long&) @ 0x0000000024612dc8 6. ./src/Functions/keyvaluepair/impl/CHKeyValuePairExtractor.h:49: DB::CHKeyValuePairExtractor::extract(std::basic_string_view>, COW::mutable_ptr&, COW::mutable_ptr&) @ 0x00000000246121fa 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::ExtractKeyValuePairs::extract(COW::immutable_ptr, std::shared_ptr) const @ 0x000000002460d4e6 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::ExtractKeyValuePairs::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002460cb79 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 24. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 27. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 30. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 31. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 2025.03.05 21:10:01.961499 [ 14974 ] {43bc249d-069f-41e0-80b9-4aeb4dcd09bc} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 53. DB::Exception: Automatically defined type String for column 'x' in row 1 differs from type defined by previous rows: Int64. You can specify the type for this column using setting schema_inference_hints. (TYPE_MISMATCH) (version 24.3.12.76.altinitystable). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.3.12.76.altinitystable) (from [::1]:40078) (comment: 02497_schema_inference_nulls.sql) (in query: desc format(JSONEachRow, '{"x" : 1234}, {"x" : "String"}') settings input_format_json_try_infer_numbers_from_strings=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:279: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351840a 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4f121d 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:01.961625 [ 14974 ] {43bc249d-069f-41e0-80b9-4aeb4dcd09bc} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 53. DB::Exception: Automatically defined type String for column 'x' in row 1 differs from type defined by previous rows: Int64. You can specify the type for this column using setting schema_inference_hints. (TYPE_MISMATCH) (version 24.3.12.76.altinitystable). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:279: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351840a 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4f121d 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:01.996507 [ 14974 ] {3551197e-e877-4961-9709-ff3bc358e961} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 53. DB::Exception: Automatically defined type String for column '1' in row 1 differs from type defined by previous rows: Int64. You can specify the type for this column using setting schema_inference_hints. (TYPE_MISMATCH) (version 24.3.12.76.altinitystable). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.3.12.76.altinitystable) (from [::1]:40078) (comment: 02497_schema_inference_nulls.sql) (in query: desc format(JSONCompactEachRow, '[1234], ["String"]') settings input_format_json_try_infer_numbers_from_strings=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:279: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351840a 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4f121d 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:01.996662 [ 14974 ] {3551197e-e877-4961-9709-ff3bc358e961} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 53. DB::Exception: Automatically defined type String for column '1' in row 1 differs from type defined by previous rows: Int64. You can specify the type for this column using setting schema_inference_hints. (TYPE_MISMATCH) (version 24.3.12.76.altinitystable). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:279: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351840a 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4f121d 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:03.131894 [ 14974 ] {0a0a0dcc-4144-4ce6-a831-5512973fe715} executeQuery: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 27.89 GiB (attempt to allocate chunk of 2148172600 bytes), maximum: 27.54 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: while converting source column `concat(toString(number), '_')` to destination column fat: while executing 'FUNCTION _CAST(concat(toString(number), '_') :: 1, FixedString(160000) :: 3) -> _CAST(concat(toString(number), '_'), FixedString(160000)) FixedString(160000) : 2'. (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:40082) (comment: 02497_remote_disk_fat_column.sql) (in query: insert into fat_granularity select number, toString(number) || '_' from numbers(100000) settings max_block_size = 8192, max_insert_threads=8;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 9. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000018067b94 11. ./src/Common/PODArray.h:405: DB::PODArray, 63ul, 64ul>::resize_fill(unsigned long) @ 0x00000000246a9e7d 12. COW::immutable_ptr DB::FunctionToFixedString::executeForN<(DB::ConvertToFixedStringExceptionMode)0>(std::vector> const&, unsigned long) @ 0x00000000187d84c3 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, unsigned long) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001853a6c4 14. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 17. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:03.561255 [ 12524 ] {cf288c41-82ba-4292-a77d-49a4fd00c75e} executeQuery: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'z'). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:40152) (comment: 02496_format_datetime_in_joda_syntax.sql) (in query: -- { echoOff } SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'z');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8ecf77 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dce2e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.561748 [ 12524 ] {cf288c41-82ba-4292-a77d-49a4fd00c75e} TCPHandler: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'z'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8ecf77 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dce2e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.561740 [ 14974 ] {0a0a0dcc-4144-4ce6-a831-5512973fe715} TCPHandler: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 27.89 GiB (attempt to allocate chunk of 2148172600 bytes), maximum: 27.54 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: while converting source column `concat(toString(number), '_')` to destination column fat: while executing 'FUNCTION _CAST(concat(toString(number), '_') :: 1, FixedString(160000) :: 3) -> _CAST(concat(toString(number), '_'), FixedString(160000)) FixedString(160000) : 2'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 9. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000018067b94 11. ./src/Common/PODArray.h:405: DB::PODArray, 63ul, 64ul>::resize_fill(unsigned long) @ 0x00000000246a9e7d 12. COW::immutable_ptr DB::FunctionToFixedString::executeForN<(DB::ConvertToFixedStringExceptionMode)0>(std::vector> const&, unsigned long) @ 0x00000000187d84c3 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, unsigned long) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001853a6c4 14. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 17. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:03.564145 [ 12524 ] {f7f5d51d-c97e-4d38-bf3a-e1f52f4d1cdf} executeQuery: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'zz'). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:40152) (comment: 02496_format_datetime_in_joda_syntax.sql) (in query: SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'zz');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8ecf77 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dce2e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.564285 [ 12524 ] {f7f5d51d-c97e-4d38-bf3a-e1f52f4d1cdf} TCPHandler: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'zz'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8ecf77 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dce2e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.565864 [ 12524 ] {ebb2dcaa-d6d4-40f7-91af-eb4948f11dcc} executeQuery: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'zzz'). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:40152) (comment: 02496_format_datetime_in_joda_syntax.sql) (in query: SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'zzz');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8ecf77 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dce2e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.565989 [ 12524 ] {ebb2dcaa-d6d4-40f7-91af-eb4948f11dcc} TCPHandler: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'zzz'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8ecf77 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dce2e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.594433 [ 12524 ] {a5debd0e-ed8f-4bf9-b959-21f3fdb96746} executeQuery: Code: 48. DB::Exception: format is not supported for TIMEZONE_OFFSET_ID: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'Z'). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:40152) (comment: 02496_format_datetime_in_joda_syntax.sql) (in query: SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'Z');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8ece31 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dce2e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.594644 [ 12524 ] {a5debd0e-ed8f-4bf9-b959-21f3fdb96746} TCPHandler: Code: 48. DB::Exception: format is not supported for TIMEZONE_OFFSET_ID: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'Z'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8ece31 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dce2e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.624452 [ 12524 ] {321a3d5c-8985-4e0c-880e-a0c749bd2b88} executeQuery: Code: 48. DB::Exception: format is not supported for b: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'b'). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:40152) (comment: 02496_format_datetime_in_joda_syntax.sql) (in query: SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'b');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8ecef1 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dce2e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.624609 [ 12524 ] {321a3d5c-8985-4e0c-880e-a0c749bd2b88} TCPHandler: Code: 48. DB::Exception: format is not supported for b: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'b'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8ecef1 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dce2e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.653458 [ 12524 ] {e484b3d3-76d2-4489-8d4d-6dcbd507a948} executeQuery: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'z'). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:40152) (comment: 02496_format_datetime_in_joda_syntax.sql) (in query: SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'z');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8e8e37 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dbb1d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.653680 [ 12524 ] {e484b3d3-76d2-4489-8d4d-6dcbd507a948} TCPHandler: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'z'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8e8e37 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dbb1d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.655892 [ 12524 ] {21055844-6383-4699-ae88-0ab9d7bb48be} executeQuery: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'zz'). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:40152) (comment: 02496_format_datetime_in_joda_syntax.sql) (in query: SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'zz');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8e8e37 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dbb1d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.656034 [ 12524 ] {21055844-6383-4699-ae88-0ab9d7bb48be} TCPHandler: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'zz'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8e8e37 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dbb1d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.657935 [ 12524 ] {d8fd72c4-79c6-4fb4-ab1e-5c3d318e829e} executeQuery: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'zzz'). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:40152) (comment: 02496_format_datetime_in_joda_syntax.sql) (in query: SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'zzz');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8e8e37 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dbb1d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.658065 [ 12524 ] {d8fd72c4-79c6-4fb4-ab1e-5c3d318e829e} TCPHandler: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'zzz'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8e8e37 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dbb1d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.686780 [ 12524 ] {e289f88d-2710-474b-9644-6a4cca8a2c37} executeQuery: Code: 48. DB::Exception: format is not supported for TIMEZONE_OFFSET_ID: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'Z'). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:40152) (comment: 02496_format_datetime_in_joda_syntax.sql) (in query: SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'Z');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8e8cf1 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dbb1d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.687047 [ 12524 ] {e289f88d-2710-474b-9644-6a4cca8a2c37} TCPHandler: Code: 48. DB::Exception: format is not supported for TIMEZONE_OFFSET_ID: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'Z'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8e8cf1 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dbb1d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.717744 [ 12524 ] {d09d554c-c849-4490-b8ee-f6124bef5b23} executeQuery: Code: 48. DB::Exception: format is not supported for b: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'b'). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:40152) (comment: 02496_format_datetime_in_joda_syntax.sql) (in query: SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'b');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8e8db1 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dbb1d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.717998 [ 12524 ] {d09d554c-c849-4490-b8ee-f6124bef5b23} TCPHandler: Code: 48. DB::Exception: format is not supported for b: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'b'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8e8db1 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dbb1d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.748972 [ 12524 ] {d4dda8f1-1716-486c-af1e-c15b22023997} executeQuery: Code: 36. DB::Exception: No closing single quote for literal: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), '\'aaaa\'\''). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40152) (comment: 02496_format_datetime_in_joda_syntax.sql) (in query: SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), '\'aaaa\'\'');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8e8bf1 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dbb1d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:03.749304 [ 12524 ] {d4dda8f1-1716-486c-af1e-c15b22023997} TCPHandler: Code: 36. DB::Exception: No closing single quote for literal: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), '\'aaaa\'\''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseJodaFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001b8e8bf1 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8dbb1d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:04.165867 [ 14973 ] {901aa49c-951f-4549-b9a4-e2dbc6fe6cfb} executeQuery: Code: 207. DB::Exception: JOIN test_m2qkzzvj.t ALL RIGHT JOIN test_m2qkzzvj.tj USING (key1, key2) ambiguous identifier 'b'. In scope SELECT b FROM t ALL RIGHT JOIN tj USING (key1, key2) ORDER BY key1 ASC. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:40208) (comment: 02495_analyzer_storage_join.sql) (in query: SELECT b FROM t ALL RIGHT JOIN tj USING (key1, key2) ORDER BY key1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cce56 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.166064 [ 14973 ] {901aa49c-951f-4549-b9a4-e2dbc6fe6cfb} TCPHandler: Code: 207. DB::Exception: JOIN test_m2qkzzvj.t ALL RIGHT JOIN test_m2qkzzvj.tj USING (key1, key2) ambiguous identifier 'b'. In scope SELECT b FROM t ALL RIGHT JOIN tj USING (key1, key2) ORDER BY key1 ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cce56 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.168116 [ 14973 ] {22e96eeb-fff5-4587-9e36-80c3286361d4} executeQuery: Code: 207. DB::Exception: JOIN test_m2qkzzvj.t ALL RIGHT JOIN test_m2qkzzvj.tj USING (key1, key2) ambiguous identifier 'x'. In scope SELECT x FROM t ALL RIGHT JOIN tj USING (key1, key2) ORDER BY key1 ASC. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:40208) (comment: 02495_analyzer_storage_join.sql) (in query: SELECT x FROM t ALL RIGHT JOIN tj USING (key1, key2) ORDER BY key1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cce56 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.168225 [ 14973 ] {22e96eeb-fff5-4587-9e36-80c3286361d4} TCPHandler: Code: 207. DB::Exception: JOIN test_m2qkzzvj.t ALL RIGHT JOIN test_m2qkzzvj.tj USING (key1, key2) ambiguous identifier 'x'. In scope SELECT x FROM t ALL RIGHT JOIN tj USING (key1, key2) ORDER BY key1 ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cce56 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.195608 [ 14973 ] {bc10ce6a-0d8b-41a1-84e9-c12c73307b6c} executeQuery: Code: 207. DB::Exception: JOIN test_m2qkzzvj.t ALL RIGHT JOIN test_m2qkzzvj.tj ON (test_m2qkzzvj.t.key1 = test_m2qkzzvj.tj.key1) AND (test_m2qkzzvj.t.key2 = test_m2qkzzvj.tj.key2) ambiguous identifier 'key1'. In scope SELECT key1 FROM t ALL RIGHT JOIN tj ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) ORDER BY t.key1 ASC. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:40208) (comment: 02495_analyzer_storage_join.sql) (in query: SELECT key1 FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 ORDER BY t.key1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cce56 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.195739 [ 14973 ] {bc10ce6a-0d8b-41a1-84e9-c12c73307b6c} TCPHandler: Code: 207. DB::Exception: JOIN test_m2qkzzvj.t ALL RIGHT JOIN test_m2qkzzvj.tj ON (test_m2qkzzvj.t.key1 = test_m2qkzzvj.tj.key1) AND (test_m2qkzzvj.t.key2 = test_m2qkzzvj.tj.key2) ambiguous identifier 'key1'. In scope SELECT key1 FROM t ALL RIGHT JOIN tj ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) ORDER BY t.key1 ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cce56 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.258950 [ 14973 ] {31b3acf1-c747-4610-9751-5c61541f06ad} executeQuery: Code: 207. DB::Exception: JOIN test_m2qkzzvj.t ALL RIGHT JOIN test_m2qkzzvj.tj ON (test_m2qkzzvj.t.key1 = test_m2qkzzvj.tj.key1) AND (test_m2qkzzvj.t.key2 = test_m2qkzzvj.tj.key2) ambiguous identifier 'b'. In scope SELECT b FROM t ALL RIGHT JOIN tj ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) ORDER BY t.key1 ASC. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:40208) (comment: 02495_analyzer_storage_join.sql) (in query: SELECT b FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 ORDER BY t.key1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cce56 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.259147 [ 14973 ] {31b3acf1-c747-4610-9751-5c61541f06ad} TCPHandler: Code: 207. DB::Exception: JOIN test_m2qkzzvj.t ALL RIGHT JOIN test_m2qkzzvj.tj ON (test_m2qkzzvj.t.key1 = test_m2qkzzvj.tj.key1) AND (test_m2qkzzvj.t.key2 = test_m2qkzzvj.tj.key2) ambiguous identifier 'b'. In scope SELECT b FROM t ALL RIGHT JOIN tj ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) ORDER BY t.key1 ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cce56 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.261148 [ 14973 ] {979a2a2f-3e1f-46e0-823a-8fc0584ece09} executeQuery: Code: 207. DB::Exception: JOIN test_m2qkzzvj.t ALL RIGHT JOIN test_m2qkzzvj.tj ON (test_m2qkzzvj.t.key1 = test_m2qkzzvj.tj.key1) AND (test_m2qkzzvj.t.key2 = test_m2qkzzvj.tj.key2) ambiguous identifier 'x'. In scope SELECT x FROM t ALL RIGHT JOIN tj ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) ORDER BY t.key1 ASC. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:40208) (comment: 02495_analyzer_storage_join.sql) (in query: SELECT x FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 ORDER BY t.key1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cce56 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.261327 [ 14973 ] {979a2a2f-3e1f-46e0-823a-8fc0584ece09} TCPHandler: Code: 207. DB::Exception: JOIN test_m2qkzzvj.t ALL RIGHT JOIN test_m2qkzzvj.tj ON (test_m2qkzzvj.t.key1 = test_m2qkzzvj.tj.key1) AND (test_m2qkzzvj.t.key2 = test_m2qkzzvj.tj.key2) ambiguous identifier 'x'. In scope SELECT x FROM t ALL RIGHT JOIN tj ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) ORDER BY t.key1 ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cce56 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.296719 [ 14973 ] {8e40df37-0682-4056-a398-52dc49289628} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column 'plus(__table2.key2, 1_UInt8)' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.3.12.76.altinitystable) (from [::1]:40208) (comment: 02495_analyzer_storage_join.sql) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 + 1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v8::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000003109df9b 4. ./build_docker/./src/Planner/PlannerJoins.cpp:860: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a7c7 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.296925 [ 14973 ] {8e40df37-0682-4056-a398-52dc49289628} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column 'plus(__table2.key2, 1_UInt8)' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v8::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000003109df9b 4. ./build_docker/./src/Planner/PlannerJoins.cpp:860: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a7c7 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.306636 [ 14973 ] {cfefa26e-0f50-4cd1-881e-5b1d0b654226} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '_CAST(1_UInt8, 'UInt8'_String)' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.3.12.76.altinitystable) (from [::1]:40208) (comment: 02495_analyzer_storage_join.sql) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 AND 1 == 1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v8::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000003109df9b 4. ./build_docker/./src/Planner/PlannerJoins.cpp:860: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a7c7 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.306739 [ 14973 ] {cfefa26e-0f50-4cd1-881e-5b1d0b654226} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '_CAST(1_UInt8, 'UInt8'_String)' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v8::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000003109df9b 4. ./build_docker/./src/Planner/PlannerJoins.cpp:860: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a7c7 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.324065 [ 14973 ] {fcc19258-2648-456e-bbbc-0d1d1b28d475} executeQuery: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [key1, key2]. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.3.12.76.altinitystable) (from [::1]:40208) (comment: 02495_analyzer_storage_join.sql) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 AND 1 == 2 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Storages/StorageJoin.cpp:197: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x0000000032249d1a 5. ./build_docker/./src/Planner/PlannerJoins.cpp:867: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000310991d5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.324253 [ 14973 ] {fcc19258-2648-456e-bbbc-0d1d1b28d475} TCPHandler: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [key1, key2]. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Storages/StorageJoin.cpp:197: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x0000000032249d1a 5. ./build_docker/./src/Planner/PlannerJoins.cpp:867: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000310991d5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.327561 [ 14973 ] {0b75fed0-da12-4500-862b-43b147a68fdc} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column 'equals(__table2.a, 20_UInt8)' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.3.12.76.altinitystable) (from [::1]:40208) (comment: 02495_analyzer_storage_join.sql) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 AND tj.a == 20 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v8::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000003109df9b 4. ./build_docker/./src/Planner/PlannerJoins.cpp:860: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a7c7 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.327665 [ 14973 ] {0b75fed0-da12-4500-862b-43b147a68fdc} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column 'equals(__table2.a, 20_UInt8)' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v8::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000003109df9b 4. ./build_docker/./src/Planner/PlannerJoins.cpp:860: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a7c7 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.335891 [ 14973 ] {94be4702-090d-4adb-86f2-74ecba029385} executeQuery: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [key1, key2]. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.3.12.76.altinitystable) (from [::1]:40208) (comment: 02495_analyzer_storage_join.sql) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 AND 1 != 1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Storages/StorageJoin.cpp:197: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x0000000032249d1a 5. ./build_docker/./src/Planner/PlannerJoins.cpp:867: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000310991d5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.335990 [ 14973 ] {94be4702-090d-4adb-86f2-74ecba029385} TCPHandler: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [key1, key2]. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Storages/StorageJoin.cpp:197: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x0000000032249d1a 5. ./build_docker/./src/Planner/PlannerJoins.cpp:867: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000310991d5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.338182 [ 14973 ] {fcb240cb-db03-4e97-ad14-44ca63460da6} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.3.12.76.altinitystable) (from [::1]:40208) (comment: 02495_analyzer_storage_join.sql) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 AND NULL FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v8::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000003109df9b 4. ./build_docker/./src/Planner/PlannerJoins.cpp:860: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a7c7 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.338280 [ 14973 ] {fcb240cb-db03-4e97-ad14-44ca63460da6} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v8::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000003109df9b 4. ./build_docker/./src/Planner/PlannerJoins.cpp:860: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a7c7 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.364905 [ 14973 ] {4b5f4837-ee23-401d-a54a-865436347cdc} executeQuery: Code: 43. DB::Exception: Illegal type (String) of 3 argument of function and: In scope SELECT * FROM t ALL RIGHT JOIN tj ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) AND 'aaa'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:40208) (comment: 02495_analyzer_storage_join.sql) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 AND 'aaa' FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000018082175 4. ./build_docker/./src/Functions/FunctionsLogical.cpp:0: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002e8c050b 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dcf56 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.365153 [ 14973 ] {4b5f4837-ee23-401d-a54a-865436347cdc} TCPHandler: Code: 43. DB::Exception: Illegal type (String) of 3 argument of function and: In scope SELECT * FROM t ALL RIGHT JOIN tj ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) AND 'aaa'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000018082175 4. ./build_docker/./src/Functions/FunctionsLogical.cpp:0: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002e8c050b 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dcf56 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.383743 [ 14973 ] {942f2354-6094-45fa-a2ec-e16456e42b36} executeQuery: Code: 403. DB::Exception: JOIN test_m2qkzzvj.t AS __table1 ALL RIGHT JOIN test_m2qkzzvj.tj AS __table2 ON 'aaa' join expression expected function. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:40208) (comment: 02495_analyzer_storage_join.sql) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON 'aaa' FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000031097587 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.383877 [ 14973 ] {942f2354-6094-45fa-a2ec-e16456e42b36} TCPHandler: Code: 403. DB::Exception: JOIN test_m2qkzzvj.t AS __table1 ALL RIGHT JOIN test_m2qkzzvj.tj AS __table2 ON 'aaa' join expression expected function. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000031097587 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.386557 [ 14973 ] {c85d4e8a-b69e-4f26-8448-b10707a2be0e} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '1_UInt8' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.3.12.76.altinitystable) (from [::1]:40208) (comment: 02495_analyzer_storage_join.sql) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 AND 1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v8::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000003109df9b 4. ./build_docker/./src/Planner/PlannerJoins.cpp:860: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a7c7 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.386745 [ 14973 ] {c85d4e8a-b69e-4f26-8448-b10707a2be0e} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '1_UInt8' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v8::join_view, std::__wrap_iter, char>&&, String const&) @ 0x000000003109df9b 4. ./build_docker/./src/Planner/PlannerJoins.cpp:860: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a7c7 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.388532 [ 14973 ] {d93e18da-38cf-49c2-ac2e-a9b5b52c091a} executeQuery: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [key1, key2]. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.3.12.76.altinitystable) (from [::1]:40208) (comment: 02495_analyzer_storage_join.sql) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON 0 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Storages/StorageJoin.cpp:197: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x0000000032249d1a 5. ./build_docker/./src/Planner/PlannerJoins.cpp:867: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000310991d5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.388660 [ 14973 ] {d93e18da-38cf-49c2-ac2e-a9b5b52c091a} TCPHandler: Code: 264. DB::Exception: JOIN keys should match to the Join engine keys [key1, key2]. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Storages/StorageJoin.cpp:197: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x0000000032249d1a 5. ./build_docker/./src/Planner/PlannerJoins.cpp:867: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000310991d5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.406386 [ 14973 ] {89bfb2cb-8f47-4348-abc1-a09ab3c02ff7} executeQuery: Code: 264. DB::Exception: Table 'test_m2qkzzvj.tj (2a2f85e7-6f1c-47fc-9432-ab4faaacc4b3)' has incompatible type of JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.3.12.76.altinitystable) (from [::1]:40208) (comment: 02495_analyzer_storage_join.sql) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON 1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageJoin.cpp:0: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x0000000032249be7 5. ./build_docker/./src/Planner/PlannerJoins.cpp:867: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000310991d5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.406518 [ 14973 ] {89bfb2cb-8f47-4348-abc1-a09ab3c02ff7} TCPHandler: Code: 264. DB::Exception: Table 'test_m2qkzzvj.tj (2a2f85e7-6f1c-47fc-9432-ab4faaacc4b3)' has incompatible type of JOIN. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageJoin.cpp:0: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x0000000032249be7 5. ./build_docker/./src/Planner/PlannerJoins.cpp:867: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000310991d5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.654515 [ 3522 ] {929f92ff-95d2-41d8-854f-c671e8c90e3d} executeQuery: Code: 36. DB::Exception: Using storage_file_read_method=mmap is not safe in server mode. Consider using pread.: While executing File. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40266) (comment: 02497_storage_file_reader_selection.sh) (in query: SELECT * FROM file('/dev/null', 'LineAsString') FORMAT Null -- { serverError BAD_ARGUMENTS }), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageFile.cpp:250: DB::(anonymous namespace)::createReadBuffer(String const&, stat const&, bool, int, String const&, std::shared_ptr) @ 0x00000000321dc440 5. ./build_docker/./src/Storages/StorageFile.cpp:1382: DB::StorageFileSource::generate() @ 0x00000000321eb03f 6. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:04.654862 [ 3522 ] {929f92ff-95d2-41d8-854f-c671e8c90e3d} TCPHandler: Code: 36. DB::Exception: Using storage_file_read_method=mmap is not safe in server mode. Consider using pread.: While executing File. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageFile.cpp:250: DB::(anonymous namespace)::createReadBuffer(String const&, stat const&, bool, int, String const&, std::shared_ptr) @ 0x00000000321dc440 5. ./build_docker/./src/Storages/StorageFile.cpp:1382: DB::StorageFileSource::generate() @ 0x00000000321eb03f 6. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.522678 [ 14973 ] {7e6b31f2-5b2e-4d48-9049-9fe69457c4f8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:40448) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.522848 [ 14973 ] {7e6b31f2-5b2e-4d48-9049-9fe69457c4f8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.662132 [ 1334 ] {} 225ff521-20e9-4c25-9628-b5ccb989a491::all_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003436efff 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:66: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000003436d557 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000323e8fd3 7. ./contrib/llvm-project/libcxx/include/vector:580: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000032e78b2d 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032f3f263 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000032f3c41e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032addf0f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032adec9e 12. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 13. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:06.662170 [ 1335 ] {} 225ff521-20e9-4c25-9628-b5ccb989a491::all_1_1_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003436efff 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:66: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000003436d557 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000323e8fd3 7. ./contrib/llvm-project/libcxx/include/vector:580: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000032e78b2d 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032f3f263 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000032f3c41e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032addf0f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032adec9e 12. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 13. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:06.662433 [ 1334 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {225ff521-20e9-4c25-9628-b5ccb989a491::all_0_0_0_2}: Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003436efff 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:66: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000003436d557 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000323e8fd3 7. ./contrib/llvm-project/libcxx/include/vector:580: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000032e78b2d 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032f3f263 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000032f3c41e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032addf0f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032adec9e 12. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 13. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:06.662447 [ 1335 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {225ff521-20e9-4c25-9628-b5ccb989a491::all_1_1_0_2}: Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./src/Common/ZooKeeper/IKeeper.h:490: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003436efff 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:66: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000003436d557 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000323e8fd3 7. ./contrib/llvm-project/libcxx/include/vector:580: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x0000000032e78b2d 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032f3f263 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000032f3c41e 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032addf0f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032adec9e 12. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 13. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:06.745313 [ 14973 ] {277324bb-c8cf-486a-8bad-1489b2dc662b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:40470) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.745450 [ 14973 ] {277324bb-c8cf-486a-8bad-1489b2dc662b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.749917 [ 14973 ] {53293de3-8c3f-466f-9a47-afd0b4178025} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:40480) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.750049 [ 14973 ] {53293de3-8c3f-466f-9a47-afd0b4178025} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.753882 [ 14973 ] {da5603fe-b350-45b0-9c44-30e4200bbaa8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:40496) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.753986 [ 14973 ] {da5603fe-b350-45b0-9c44-30e4200bbaa8} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.757237 [ 14973 ] {b5c237bd-6651-4c10-8e5e-dbb2f6609bf4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:40498) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.757387 [ 14973 ] {b5c237bd-6651-4c10-8e5e-dbb2f6609bf4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.760061 [ 14973 ] {40a2cdd1-92f1-4012-977b-4343eb0b206a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:40506) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.760173 [ 14973 ] {40a2cdd1-92f1-4012-977b-4343eb0b206a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.762775 [ 14973 ] {0fbedfb9-2935-4985-b6da-ab1387953fbf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:40512) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.762857 [ 14973 ] {0fbedfb9-2935-4985-b6da-ab1387953fbf} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.765414 [ 14973 ] {67bec712-1a80-42e3-a9df-ac68e8b552df} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:40518) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.765496 [ 14973 ] {67bec712-1a80-42e3-a9df-ac68e8b552df} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.769167 [ 14973 ] {b2d3b62b-e695-411b-bb06-d9e2dd682941} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:40532) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.769261 [ 14973 ] {b2d3b62b-e695-411b-bb06-d9e2dd682941} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.772119 [ 14973 ] {d9a004ba-8162-4af0-a956-71aac6f9517c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:40548) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.772222 [ 14973 ] {d9a004ba-8162-4af0-a956-71aac6f9517c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.775529 [ 14973 ] {60c5b456-fabc-4f46-a691-aaa661151614} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:40552) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:06.775671 [ 14973 ] {60c5b456-fabc-4f46-a691-aaa661151614} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:07.927583 [ 730 ] {} Access(user directories): from: ::1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:07.927825 [ 730 ] {} ServerErrorHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:07.995893 [ 730 ] {test_sfuj5nzq_1741205407_02883_q1} executeQuery: Code: 47. DB::Exception: Unknown expression or table expression identifier 'sub' in scope SELECT * FROM system.numbers WHERE number IN (sub). Maybe you meant: ['sub']. (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:40648) (comment: 02483_elapsed_time.sh) (in query: WITH ( SELECT sleepEachRow(1) ) AS sub SELECT * FROM ( SELECT * FROM system.numbers WHERE number IN (sub) ) SETTINGS enable_global_with_statement = 0, allow_experimental_analyzer = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6519: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882639 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7911: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd42 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:07.996221 [ 730 ] {test_sfuj5nzq_1741205407_02883_q1} TCPHandler: Code: 47. DB::Exception: Unknown expression or table expression identifier 'sub' in scope SELECT * FROM system.numbers WHERE number IN (sub). Maybe you meant: ['sub']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6519: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882639 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7911: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd42 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:08.101950 [ 730 ] {} Access(user directories): from: ::1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:08.102283 [ 730 ] {} ServerErrorHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:08.128610 [ 12524 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:08.128875 [ 12524 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:08.135020 [ 12524 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:08.135259 [ 12524 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:08.231084 [ 14974 ] {0b0934f6-966c-48eb-b153-bbe7545388b3} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 't2.value'. In scope SELECT toTypeName(t2_value), t2.value AS t2_value FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 USING (id). Maybe you meant: ['t1.value']. (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:40664) (comment: 02481_analyzer_join_alias_unknown_identifier_crash.sql) (in query: SELECT toTypeName(t2_value), t2.value AS t2_value FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 USING (id);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String const&, String&&, String&&) @ 0x0000000030921b09 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x00000000308a096c 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:08.231325 [ 14974 ] {0b0934f6-966c-48eb-b153-bbe7545388b3} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 't2.value'. In scope SELECT toTypeName(t2_value), t2.value AS t2_value FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 USING (id). Maybe you meant: ['t1.value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String const&, String&&, String&&) @ 0x0000000030921b09 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x00000000308a096c 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:08.392494 [ 14974 ] {319281aa-eb3a-416b-8fdd-cd181ea4739a} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION intDiv(__table1.b :: 2, __table1.c :: 0) -> intDiv(__table1.b, __table1.c) Int32 : 1'. (ILLEGAL_DIVISION) (version 24.3.12.76.altinitystable) (from [::1]:40682) (comment: 02481_prewhere_filtered_rows_div_by_zero.sql) (in query: -- Check that division by zero occurs on some rows SELECT intDiv(b, c) FROM test_filter;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000001aacf296 5. void DB::(anonymous namespace)::DivideIntegralByConstantImpl::apply<(DB::impl_::OpCase)0>(int const*, int const*, int*, unsigned long) @ 0x000000001cee89db 6. void DB::(anonymous namespace)::DivideIntegralByConstantImpl::process<(DB::impl_::OpCase)0>(int const*, int const*, int*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001cee8513 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d316361 8. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001d315e22 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d30d45f 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d2520c1 11. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d24d3ac 12. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d24a585 13. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 20. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 21. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 26. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 27. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:08.392748 [ 14974 ] {319281aa-eb3a-416b-8fdd-cd181ea4739a} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION intDiv(__table1.b :: 2, __table1.c :: 0) -> intDiv(__table1.b, __table1.c) Int32 : 1'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000001aacf296 5. void DB::(anonymous namespace)::DivideIntegralByConstantImpl::apply<(DB::impl_::OpCase)0>(int const*, int const*, int*, unsigned long) @ 0x000000001cee89db 6. void DB::(anonymous namespace)::DivideIntegralByConstantImpl::process<(DB::impl_::OpCase)0>(int const*, int const*, int*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001cee8513 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d316361 8. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001d315e22 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d30d45f 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d2520c1 11. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d24d3ac 12. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d24a585 13. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 20. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 21. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 26. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 27. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:10.532830 [ 730 ] {e9ec2160-fac4-490a-9a03-74a055d8fa2d} executeQuery: Code: 10. DB::Exception: Not found column dt: in block __table1.pk Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.3.12.76.altinitystable) (from [::1]:37256) (comment: 02479_analyzer_join_with_constants.sql) (in query: SELECT b.dt FROM (SELECT NULL > NULL AS pk, 1 AS dt FROM numbers(5)) AS a ASOF LEFT JOIN (SELECT NULL AS pk, 1 AS dt) AS b ON (a.pk = b.pk) AND 1 != 1 AND (a.dt >= b.dt);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:824: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb69246 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1122: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069f0f 9. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:10.533117 [ 730 ] {e9ec2160-fac4-490a-9a03-74a055d8fa2d} TCPHandler: Code: 10. DB::Exception: Not found column dt: in block __table1.pk Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:824: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb69246 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1122: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069f0f 9. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:11.614383 [ 730 ] {c7261935-2d29-4d2f-93d7-cffa21cc12eb} executeQuery: Code: 36. DB::Exception: The maximum value for the input argument of function factorial is 20: In scope SELECT factorial(100). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37772) (comment: 02478_factorial.sql) (in query: select factorial(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000001b875bfd 5. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000001b871962 6. bool DB::FunctionUnaryArithmetic::castType::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001b871146 7. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b870a4d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:10:11.614569 [ 730 ] {c7261935-2d29-4d2f-93d7-cffa21cc12eb} TCPHandler: Code: 36. DB::Exception: The maximum value for the input argument of function factorial is 20: In scope SELECT factorial(100). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000001b875bfd 5. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000001b871962 6. bool DB::FunctionUnaryArithmetic::castType::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001b871146 7. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b870a4d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:10:11.687902 [ 730 ] {27a1883e-dbd4-4428-b84c-d74bba1806fc} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function factorial: In scope SELECT factorial('100'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:37772) (comment: 02478_factorial.sql) (in query: select factorial('100');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001b87c959 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:11.696855 [ 730 ] {27a1883e-dbd4-4428-b84c-d74bba1806fc} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function factorial: In scope SELECT factorial('100'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001b87c959 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:11.782790 [ 730 ] {e70eb4c8-cf1e-4826-b613-e6b2f2cea644} executeQuery: Code: 43. DB::Exception: Illegal type of argument of function factorial, should not be floating point or big int: In scope SELECT factorial(100.1234). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:37772) (comment: 02478_factorial.sql) (in query: select factorial(100.1234);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000001b87baa5 5. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000001b8750c6 6. bool DB::FunctionUnaryArithmetic::castType::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001b871486 7. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b870a4d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:10:11.783037 [ 730 ] {e70eb4c8-cf1e-4826-b613-e6b2f2cea644} TCPHandler: Code: 43. DB::Exception: Illegal type of argument of function factorial, should not be floating point or big int: In scope SELECT factorial(100.1234). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000001b87baa5 5. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000001b8750c6 6. bool DB::FunctionUnaryArithmetic::castType::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001b871486 7. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b870a4d 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:10:12.755459 [ 5753 ] {ff830cf7-f95b-4eae-92d2-d9e9d49a2ca2} executeQuery: Code: 131. DB::Exception: String size is too big (2147483648), maximum: 2147483647: while executing 'FUNCTION CAST(concat(_CAST('ÿÿÿ'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('ÿÿÿ'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (TOO_LARGE_STRING_SIZE) (version 24.3.12.76.altinitystable) (from [::1]:38416) (comment: 02477_single_value_data_string_regression.sql) (in query: SELECT '2^31-1', maxMerge(x) from (select CAST(unhex('ffffff7f') || randomString(100500), 'AggregateFunction(max, String)') as x);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, unsigned int const&) @ 0x0000000026c281c0 4. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1075: DB::SingleValueDataString::allocateLargeDataIfNeeded(unsigned int, DB::Arena*) @ 0x0000000026bbb9e7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1154: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000026bbca04 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 22. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 23. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 24. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:12.755983 [ 5753 ] {ff830cf7-f95b-4eae-92d2-d9e9d49a2ca2} TCPHandler: Code: 131. DB::Exception: String size is too big (2147483648), maximum: 2147483647: while executing 'FUNCTION CAST(concat(_CAST('ÿÿÿ'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('ÿÿÿ'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, unsigned int const&) @ 0x0000000026c281c0 4. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1075: DB::SingleValueDataString::allocateLargeDataIfNeeded(unsigned int, DB::Arena*) @ 0x0000000026bbb9e7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1154: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000026bbca04 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 22. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 23. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 24. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:12.826858 [ 5753 ] {27331310-b011-452d-804a-501185273b87} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 2147483646.: while executing 'FUNCTION CAST(concat(_CAST('þÿÿ'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('þÿÿ'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA) (version 24.3.12.76.altinitystable) (from [::1]:38416) (comment: 02477_single_value_data_string_regression.sql) (in query: SELECT '2^31-2', maxMerge(x) from (select CAST(unhex('feffff7f') || randomString(100500), 'AggregateFunction(max, String)') as x);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000187cb1aa 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1159: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000026bbcb18 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 22. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 23. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 24. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:12.827292 [ 5753 ] {27331310-b011-452d-804a-501185273b87} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 2147483646.: while executing 'FUNCTION CAST(concat(_CAST('þÿÿ'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('þÿÿ'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000187cb1aa 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1159: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000026bbcb18 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 22. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 23. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 24. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:12.858457 [ 5753 ] {e6622d65-0952-4a13-9fc1-a4704979db69} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 1073741824.: while executing 'FUNCTION CAST(concat(_CAST('\0\0\0@'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('\0\0\0@'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA) (version 24.3.12.76.altinitystable) (from [::1]:38416) (comment: 02477_single_value_data_string_regression.sql) (in query: SELECT '2^30', maxMerge(x) from (select CAST(unhex('00000040') || randomString(100500), 'AggregateFunction(max, String)') as x);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000187cb1aa 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1159: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000026bbcb18 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 22. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 23. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 24. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:12.858747 [ 5753 ] {e6622d65-0952-4a13-9fc1-a4704979db69} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 1073741824.: while executing 'FUNCTION CAST(concat(_CAST('\0\0\0@'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('\0\0\0@'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000187cb1aa 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1159: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000026bbcb18 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 22. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 23. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 24. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:12.872946 [ 5753 ] {c89f9594-a735-4bb5-8956-8c61a9dc22b1} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 1073741825.: while executing 'FUNCTION CAST(concat(_CAST('\0\0@'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('\0\0@'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA) (version 24.3.12.76.altinitystable) (from [::1]:38416) (comment: 02477_single_value_data_string_regression.sql) (in query: SELECT '2^30+1', maxMerge(x) from (select CAST(unhex('01000040') || randomString(100500), 'AggregateFunction(max, String)') as x);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000187cb1aa 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1159: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000026bbcb18 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 22. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 23. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 24. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:12.873304 [ 5753 ] {c89f9594-a735-4bb5-8956-8c61a9dc22b1} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 1073741825.: while executing 'FUNCTION CAST(concat(_CAST('\0\0@'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('\0\0@'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000187cb1aa 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1159: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000026bbcb18 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 22. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 23. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 24. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:12.880947 [ 5753 ] {1ceba48b-6de1-4d08-ad98-fd549b79329b} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 1073741823.: while executing 'FUNCTION CAST(concat(_CAST('ÿÿÿ?'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('ÿÿÿ?'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA) (version 24.3.12.76.altinitystable) (from [::1]:38416) (comment: 02477_single_value_data_string_regression.sql) (in query: SELECT '2^30-1', maxMerge(x) from (select CAST(unhex('ffffff3f') || randomString(100500), 'AggregateFunction(max, String)') as x);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000187cb1aa 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1159: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000026bbcb18 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 22. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 23. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 24. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:12.881249 [ 5753 ] {1ceba48b-6de1-4d08-ad98-fd549b79329b} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 1073741823.: while executing 'FUNCTION CAST(concat(_CAST('ÿÿÿ?'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('ÿÿÿ?'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000187cb1aa 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1159: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x0000000026bbcb18 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 22. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 23. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 24. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:12.978199 [ 5753 ] {20f8f580-4026-4087-874e-22fc1d4fd655} executeQuery: Code: 246. DB::Exception: Invalid state of the aggregate function argMax: has_value (true) != has_result (false): In scope SELECT 'fuzz1', finalizeAggregation(CAST(unhex('3000000\0303132333435363738393031323334353637383930313233343536373839303132333435363738393031323334353600010000000000000000'), 'AggregateFunction(argMax, String, UInt64)')). (CORRUPTED_DATA) (version 24.3.12.76.altinitystable) (from [::1]:38416) (comment: 02477_single_value_data_string_regression.sql) (in query: SELECT 'fuzz1', finalizeAggregation(CAST(unhex('3000000\0303132333435363738393031323334353637383930313233343536373839303132333435363738393031323334353600010000000000000000'), 'AggregateFunction(argMax, String, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x0000000026d4006b 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:0: DB::(anonymous namespace)::AggregateFunctionArgMinMax, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026cdf223 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 7. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:10:12.978421 [ 5753 ] {20f8f580-4026-4087-874e-22fc1d4fd655} TCPHandler: Code: 246. DB::Exception: Invalid state of the aggregate function argMax: has_value (true) != has_result (false): In scope SELECT 'fuzz1', finalizeAggregation(CAST(unhex('3000000\0303132333435363738393031323334353637383930313233343536373839303132333435363738393031323334353600010000000000000000'), 'AggregateFunction(argMax, String, UInt64)')). (CORRUPTED_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x0000000026d4006b 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:0: DB::(anonymous namespace)::AggregateFunctionArgMinMax, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026cdf223 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 7. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:10:12.995895 [ 5753 ] {d96d5af0-f1e1-4473-8494-8c62a5b5cd41} executeQuery: Code: 246. DB::Exception: Invalid state of the aggregate function argMax: has_value (false) != has_result (true): In scope SELECT 'fuzz3', finalizeAggregation(CAST(unhex(concat('04000000', '30313233', '00', 'ffffffffffffffff')), 'AggregateFunction(argMax, String, UInt64)')) AS x, length(x). (CORRUPTED_DATA) (version 24.3.12.76.altinitystable) (from [::1]:38416) (comment: 02477_single_value_data_string_regression.sql) (in query: SELECT 'fuzz3', finalizeAggregation(CAST(unhex('04000000' || '30313233' || '00' || 'ffffffffffffffff'), 'AggregateFunction(argMax, String, UInt64)')) as x, length(x);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x0000000026d4006b 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:0: DB::(anonymous namespace)::AggregateFunctionArgMinMax, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026cdf223 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 7. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:10:12.996045 [ 5753 ] {d96d5af0-f1e1-4473-8494-8c62a5b5cd41} TCPHandler: Code: 246. DB::Exception: Invalid state of the aggregate function argMax: has_value (false) != has_result (true): In scope SELECT 'fuzz3', finalizeAggregation(CAST(unhex(concat('04000000', '30313233', '00', 'ffffffffffffffff')), 'AggregateFunction(argMax, String, UInt64)')) AS x, length(x). (CORRUPTED_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x0000000026d4006b 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:0: DB::(anonymous namespace)::AggregateFunctionArgMinMax, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026cdf223 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 7. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:10:12.997776 [ 5753 ] {0734a4b9-5357-464e-b604-bfcbf795d0a9} executeQuery: Code: 246. DB::Exception: Invalid state of the aggregate function argMax: has_value (false) != has_result (true): In scope SELECT 'fuzz4', finalizeAggregation(CAST(unhex(concat('04000000', '30313233', '00')), 'AggregateFunction(argMax, String, UInt64)')) AS x, length(x). (CORRUPTED_DATA) (version 24.3.12.76.altinitystable) (from [::1]:38416) (comment: 02477_single_value_data_string_regression.sql) (in query: SELECT 'fuzz4', finalizeAggregation(CAST(unhex('04000000' || '30313233' || '00'), 'AggregateFunction(argMax, String, UInt64)')) as x, length(x);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x0000000026d4006b 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:0: DB::(anonymous namespace)::AggregateFunctionArgMinMax, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026cdf223 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 7. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:10:12.997908 [ 5753 ] {0734a4b9-5357-464e-b604-bfcbf795d0a9} TCPHandler: Code: 246. DB::Exception: Invalid state of the aggregate function argMax: has_value (false) != has_result (true): In scope SELECT 'fuzz4', finalizeAggregation(CAST(unhex(concat('04000000', '30313233', '00')), 'AggregateFunction(argMax, String, UInt64)')) AS x, length(x). (CORRUPTED_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x0000000026d4006b 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:0: DB::(anonymous namespace)::AggregateFunctionArgMinMax, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026cdf223 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 7. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:10:13.087548 [ 5753 ] {40305c7e-c39b-4885-b795-868d3f443bf5} executeQuery: Code: 246. DB::Exception: Invalid state of the aggregate function argMax: has_value (false) != has_result (true): In scope SELECT 'fuzz5', finalizeAggregation(CAST(unhex('0100000000000000000FFFFFFFF0'), 'AggregateFunction(argMax, UInt64, String)')). (CORRUPTED_DATA) (version 24.3.12.76.altinitystable) (from [::1]:38416) (comment: 02477_single_value_data_string_regression.sql) (in query: SELECT 'fuzz5', finalizeAggregation(CAST(unhex('0100000000000000000FFFFFFFF0'), 'AggregateFunction(argMax, UInt64, String)'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x0000000026d4006b 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:0: DB::(anonymous namespace)::AggregateFunctionArgMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026d35c57 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 7. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:10:13.087776 [ 5753 ] {40305c7e-c39b-4885-b795-868d3f443bf5} TCPHandler: Code: 246. DB::Exception: Invalid state of the aggregate function argMax: has_value (false) != has_result (true): In scope SELECT 'fuzz5', finalizeAggregation(CAST(unhex('0100000000000000000FFFFFFFF0'), 'AggregateFunction(argMax, UInt64, String)')). (CORRUPTED_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x0000000026d4006b 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:0: DB::(anonymous namespace)::AggregateFunctionArgMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000026d35c57 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:138: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5aff59 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5b063d 7. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (*)(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018783ea3 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:10:13.884577 [ 12524 ] {c6a91761-6d74-49a5-9e62-59ea1dc80883} executeQuery: Code: 43. DB::Exception: Illegal type of argument #3 'max_substrings' of function splitByChar, expected const Number, got String: In scope SELECT splitByChar(',', '1,2,3', ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:39146) (comment: 02475_split_with_max_substrings.sql) (in query: SELECT splitByChar(',', '1,2,3', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021638ca2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:13.891230 [ 12524 ] {c6a91761-6d74-49a5-9e62-59ea1dc80883} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #3 'max_substrings' of function splitByChar, expected const Number, got String: In scope SELECT splitByChar(',', '1,2,3', ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021638ca2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:13.961919 [ 12524 ] {0ff7df3f-3960-4a3a-9279-43ef1df1d026} executeQuery: Code: 43. DB::Exception: Illegal type of argument #3 'max_substrings' of function splitByRegexp, expected const Number, got String: In scope SELECT splitByRegexp('[ABC]', 'oneAtwoBthreeC', ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:39146) (comment: 02475_split_with_max_substrings.sql) (in query: SELECT splitByRegexp('[ABC]', 'oneAtwoBthreeC', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000002163f962 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:13.962156 [ 12524 ] {0ff7df3f-3960-4a3a-9279-43ef1df1d026} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #3 'max_substrings' of function splitByRegexp, expected const Number, got String: In scope SELECT splitByRegexp('[ABC]', 'oneAtwoBthreeC', ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000002163f962 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:14.046891 [ 12524 ] {fea2c139-7636-489b-ac8e-45dc872130cf} executeQuery: Code: 43. DB::Exception: Illegal type of argument #2 'max_substrings' of function alphaTokens, expected const Number, got String: In scope SELECT alphaTokens('abca1abc', ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:39146) (comment: 02475_split_with_max_substrings.sql) (in query: SELECT alphaTokens('abca1abc', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000001971e77f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:14.047140 [ 12524 ] {fea2c139-7636-489b-ac8e-45dc872130cf} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #2 'max_substrings' of function alphaTokens, expected const Number, got String: In scope SELECT alphaTokens('abca1abc', ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000001971e77f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:14.050119 [ 12524 ] {903dcf8b-e494-4658-8e13-7e18c1310a6b} executeQuery: Code: 43. DB::Exception: Illegal type of argument #2 'max_substrings' of function alphaTokens, expected const Number, got String: In scope SELECT splitByAlpha('abca1abc', ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:39146) (comment: 02475_split_with_max_substrings.sql) (in query: SELECT splitByAlpha('abca1abc', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000001971e77f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:14.050310 [ 12524 ] {903dcf8b-e494-4658-8e13-7e18c1310a6b} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #2 'max_substrings' of function alphaTokens, expected const Number, got String: In scope SELECT splitByAlpha('abca1abc', ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000001971e77f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:14.108371 [ 12524 ] {a4c2bdaa-df85-430e-a15d-762d0027f743} executeQuery: Code: 43. DB::Exception: Illegal type of argument #2 'max_substrings' of function splitByNonAlpha, expected const Number, got String: In scope SELECT splitByNonAlpha(' 1! a, b. ', ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:39146) (comment: 02475_split_with_max_substrings.sql) (in query: SELECT splitByNonAlpha(' 1! a, b. ', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000002163c11f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:14.114638 [ 12524 ] {a4c2bdaa-df85-430e-a15d-762d0027f743} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #2 'max_substrings' of function splitByNonAlpha, expected const Number, got String: In scope SELECT splitByNonAlpha(' 1! a, b. ', ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000002163c11f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:14.153133 [ 12524 ] {4c2464b8-c9a7-4999-8a1d-1df7215f975c} executeQuery: Code: 43. DB::Exception: Illegal type of argument #2 'max_substrings' of function splitByWhitespace, expected const Number, got String: In scope SELECT splitByWhitespace(' 1! a, b. ', ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:39146) (comment: 02475_split_with_max_substrings.sql) (in query: SELECT splitByWhitespace(' 1! a, b. ', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000002164699f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:14.153355 [ 12524 ] {4c2464b8-c9a7-4999-8a1d-1df7215f975c} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #2 'max_substrings' of function splitByWhitespace, expected const Number, got String: In scope SELECT splitByWhitespace(' 1! a, b. ', ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000002164699f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:14.235882 [ 12524 ] {4069fc17-dd7b-4754-9548-0d600ee26a79} executeQuery: Code: 43. DB::Exception: Illegal type of argument #3 'max_substrings' of function splitByString, expected const Number, got String: In scope SELECT splitByString(', ', '1, 2 3, 4,5, abcde', ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:39146) (comment: 02475_split_with_max_substrings.sql) (in query: SELECT splitByString(', ', '1, 2 3, 4,5, abcde', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x00000000216433a2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:14.236082 [ 12524 ] {4069fc17-dd7b-4754-9548-0d600ee26a79} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #3 'max_substrings' of function splitByString, expected const Number, got String: In scope SELECT splitByString(', ', '1, 2 3, 4,5, abcde', ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x00000000216433a2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.145573 [ 10241 ] {b694d4dc-7ed5-44f0-845a-aab73ebde80c} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:40592) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: SELECT * FROM (SELECT 1) FINAL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030824df6 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.145749 [ 10241 ] {b694d4dc-7ed5-44f0-845a-aab73ebde80c} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030824df6 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.147494 [ 10241 ] {77288fa6-d910-45d8-9188-ce9cb6a0476b} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:40592) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: SELECT * FROM (SELECT 1) SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030824df6 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.147667 [ 10241 ] {77288fa6-d910-45d8-9188-ce9cb6a0476b} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030824df6 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.149325 [ 10241 ] {1a2c3a1c-adba-4b38-a9f1-a20ff324270f} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:40592) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: SELECT * FROM (SELECT 1) FINAL SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030824df6 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.149461 [ 10241 ] {1a2c3a1c-adba-4b38-a9f1-a20ff324270f} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030824df6 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.184534 [ 10241 ] {f466ebf4-5a42-40d5-b008-8330be934505} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:40592) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: WITH cte_subquery AS (SELECT 1) SELECT * FROM cte_subquery FINAL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030878937 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.184820 [ 10241 ] {f466ebf4-5a42-40d5-b008-8330be934505} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030878937 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.197619 [ 10241 ] {faf9a617-2292-43eb-926d-5262de7690cc} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:40592) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: WITH cte_subquery AS (SELECT 1) SELECT * FROM cte_subquery SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030878937 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.197869 [ 10241 ] {faf9a617-2292-43eb-926d-5262de7690cc} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030878937 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.199948 [ 10241 ] {97a8e3b8-dd25-4f15-8453-ed111d5368cc} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:40592) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: WITH cte_subquery AS (SELECT 1) SELECT * FROM cte_subquery FINAL SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030878937 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.200117 [ 10241 ] {97a8e3b8-dd25-4f15-8453-ed111d5368cc} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030878937 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.201812 [ 10241 ] {898214e6-0164-47c4-ba00-484c72d734df} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:40592) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: SELECT * FROM (SELECT 1 UNION ALL SELECT 1) FINAL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030824df6 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.201983 [ 10241 ] {898214e6-0164-47c4-ba00-484c72d734df} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030824df6 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.203398 [ 10241 ] {0b160fcd-b2b4-44dc-81b7-35813c2418c8} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:40592) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: SELECT * FROM (SELECT 1 UNION ALL SELECT 1) SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030824df6 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.203503 [ 10241 ] {0b160fcd-b2b4-44dc-81b7-35813c2418c8} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030824df6 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.204811 [ 10241 ] {b14ea85d-4147-4330-a58b-24cff902a5f7} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:40592) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: SELECT * FROM (SELECT 1 UNION ALL SELECT 1) FINAL SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030824df6 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.204979 [ 10241 ] {b14ea85d-4147-4330-a58b-24cff902a5f7} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030824df6 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.206647 [ 10241 ] {c84120ae-5644-42fc-bf40-ab7f6b8ab9fd} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:40592) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: WITH cte_subquery AS (SELECT 1 UNION ALL SELECT 1) SELECT * FROM cte_subquery FINAL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030878937 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.206825 [ 10241 ] {c84120ae-5644-42fc-bf40-ab7f6b8ab9fd} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030878937 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.213613 [ 10241 ] {e3b6eb91-6e3d-439a-99cc-8c8e50bd2463} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:40592) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: WITH cte_subquery AS (SELECT 1 UNION ALL SELECT 1) SELECT * FROM cte_subquery SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030878937 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.213773 [ 10241 ] {e3b6eb91-6e3d-439a-99cc-8c8e50bd2463} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030878937 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.215474 [ 10241 ] {95279301-e08d-4a93-95d4-8a429fe6bfa8} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:40592) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (in query: WITH cte_subquery AS (SELECT 1 UNION ALL SELECT 1) SELECT * FROM cte_subquery FINAL SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030878937 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:16.215630 [ 10241 ] {95279301-e08d-4a93-95d4-8a429fe6bfa8} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030878937 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:17.824598 [ 23582 ] {96e45a13-35a8-455c-b652-ad7512316d0d} executeQuery: Code: 59. DB::Exception: Illegal type Int128 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.3.12.76.altinitystable) (from [::1]:41470) (comment: 02473_prewhere_with_bigint.sql) (in query: SELECT a FROM prewhere_int128 PREWHERE a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/FilterDescription.cpp:0: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000031fde918 5. ./src/Storages/MergeTree/MergeTreeRangeReader.h:71: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x0000000032e013de 6. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000032dfbc02 7. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1067: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df64b3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:164: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000032e04f6f 9. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000033f8b134 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:139: DB::MergeTreeSelectProcessor::read() @ 0x0000000032de396f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:0: DB::MergeTreeSource::tryGenerate() @ 0x0000000033fb1d35 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 18. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:17.824762 [ 23582 ] {96e45a13-35a8-455c-b652-ad7512316d0d} TCPHandler: Code: 59. DB::Exception: Illegal type Int128 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/FilterDescription.cpp:0: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000031fde918 5. ./src/Storages/MergeTree/MergeTreeRangeReader.h:71: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x0000000032e013de 6. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000032dfbc02 7. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1067: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df64b3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:164: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000032e04f6f 9. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000033f8b134 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:139: DB::MergeTreeSelectProcessor::read() @ 0x0000000032de396f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:0: DB::MergeTreeSource::tryGenerate() @ 0x0000000033fb1d35 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 18. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:17.856384 [ 23582 ] {07002f9e-4c07-42c7-b7a8-c1b3d9232f72} executeQuery: Code: 59. DB::Exception: Illegal type Int256 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.3.12.76.altinitystable) (from [::1]:41470) (comment: 02473_prewhere_with_bigint.sql) (in query: SELECT a FROM prewhere_int256 PREWHERE a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/FilterDescription.cpp:0: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000031fde918 5. ./src/Storages/MergeTree/MergeTreeRangeReader.h:71: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x0000000032e013de 6. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000032dfbc02 7. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1067: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df64b3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:164: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000032e04f6f 9. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000033f8b134 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:139: DB::MergeTreeSelectProcessor::read() @ 0x0000000032de396f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:0: DB::MergeTreeSource::tryGenerate() @ 0x0000000033fb1d35 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 18. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:17.856545 [ 23582 ] {07002f9e-4c07-42c7-b7a8-c1b3d9232f72} TCPHandler: Code: 59. DB::Exception: Illegal type Int256 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/FilterDescription.cpp:0: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000031fde918 5. ./src/Storages/MergeTree/MergeTreeRangeReader.h:71: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x0000000032e013de 6. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000032dfbc02 7. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1067: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df64b3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:164: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000032e04f6f 9. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000033f8b134 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:139: DB::MergeTreeSelectProcessor::read() @ 0x0000000032de396f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:0: DB::MergeTreeSource::tryGenerate() @ 0x0000000033fb1d35 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 18. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:17.894431 [ 23582 ] {e8d54997-18cf-4012-82a5-92d720893389} executeQuery: Code: 59. DB::Exception: Illegal type UInt128 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.3.12.76.altinitystable) (from [::1]:41470) (comment: 02473_prewhere_with_bigint.sql) (in query: SELECT a FROM prewhere_uint128 PREWHERE a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/FilterDescription.cpp:0: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000031fde918 5. ./src/Storages/MergeTree/MergeTreeRangeReader.h:71: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x0000000032e013de 6. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000032dfbc02 7. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1067: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df64b3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:164: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000032e04f6f 9. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000033f8b134 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:139: DB::MergeTreeSelectProcessor::read() @ 0x0000000032de396f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:0: DB::MergeTreeSource::tryGenerate() @ 0x0000000033fb1d35 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 18. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:17.894574 [ 23582 ] {e8d54997-18cf-4012-82a5-92d720893389} TCPHandler: Code: 59. DB::Exception: Illegal type UInt128 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/FilterDescription.cpp:0: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000031fde918 5. ./src/Storages/MergeTree/MergeTreeRangeReader.h:71: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x0000000032e013de 6. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000032dfbc02 7. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1067: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df64b3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:164: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000032e04f6f 9. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000033f8b134 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:139: DB::MergeTreeSelectProcessor::read() @ 0x0000000032de396f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:0: DB::MergeTreeSource::tryGenerate() @ 0x0000000033fb1d35 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 18. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:17.924841 [ 23582 ] {3c31d968-f222-4489-b7a9-32397edda062} executeQuery: Code: 59. DB::Exception: Illegal type UInt256 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.3.12.76.altinitystable) (from [::1]:41470) (comment: 02473_prewhere_with_bigint.sql) (in query: SELECT a FROM prewhere_uint256 PREWHERE a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/FilterDescription.cpp:0: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000031fde918 5. ./src/Storages/MergeTree/MergeTreeRangeReader.h:71: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x0000000032e013de 6. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000032dfbc02 7. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1067: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df64b3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:164: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000032e04f6f 9. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000033f8b134 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:139: DB::MergeTreeSelectProcessor::read() @ 0x0000000032de396f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:0: DB::MergeTreeSource::tryGenerate() @ 0x0000000033fb1d35 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 18. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:17.925059 [ 23582 ] {3c31d968-f222-4489-b7a9-32397edda062} TCPHandler: Code: 59. DB::Exception: Illegal type UInt256 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/FilterDescription.cpp:0: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x0000000031fde918 5. ./src/Storages/MergeTree/MergeTreeRangeReader.h:71: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x0000000032e013de 6. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000032dfbc02 7. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1067: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df64b3 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:164: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000032e04f6f 9. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000033f8b134 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:139: DB::MergeTreeSelectProcessor::read() @ 0x0000000032de396f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:0: DB::MergeTreeSource::tryGenerate() @ 0x0000000033fb1d35 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 18. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:21.143663 [ 22858 ] {acc91a3e-c598-4c3e-9691-afc6e7bb8b12} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 24.3.12.76.altinitystable) (from [::1]:56648) (comment: 02473_functions_in_readonly_mode.sh) (in query: SELECT * from format('TSV', '123')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper(DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed692c0 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(DB::AccessFlags) const @ 0x000000002ed6708a 6. ./build_docker/./src/Access/ContextAccess.cpp:724: DB::ContextAccess::checkAccess(DB::AccessFlags const&) const @ 0x000000002ed2afbd 7. ./build_docker/./src/Interpreters/Context.cpp:1398: void DB::Context::checkAccessImpl(DB::AccessFlags const&) const @ 0x000000002fc971fe 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:34: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e0ee4 9. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:21.144217 [ 22858 ] {acc91a3e-c598-4c3e-9691-afc6e7bb8b12} TCPHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper(DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed692c0 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(DB::AccessFlags) const @ 0x000000002ed6708a 6. ./build_docker/./src/Access/ContextAccess.cpp:724: DB::ContextAccess::checkAccess(DB::AccessFlags const&) const @ 0x000000002ed2afbd 7. ./build_docker/./src/Interpreters/Context.cpp:1398: void DB::Context::checkAccessImpl(DB::AccessFlags const&) const @ 0x000000002fc971fe 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:34: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e0ee4 9. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:21.353845 [ 23555 ] {4692f61e-6c84-49d5-a2ee-bfe5372c8b90} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 24.3.12.76.altinitystable) (from [::1]:56688) (comment: 02473_functions_in_readonly_mode.sh) (in query: INSERT INTO FUNCTION null('x String') (x) FORMAT TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper(DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed692c0 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(DB::AccessFlags) const @ 0x000000002ed6708a 6. ./build_docker/./src/Access/ContextAccess.cpp:724: DB::ContextAccess::checkAccess(DB::AccessFlags const&) const @ 0x000000002ed2afbd 7. ./build_docker/./src/Interpreters/Context.cpp:1398: void DB::Context::checkAccessImpl(DB::AccessFlags const&) const @ 0x000000002fc971fe 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:34: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e0ee4 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:107: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f308d6 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:21.354225 [ 23555 ] {4692f61e-6c84-49d5-a2ee-bfe5372c8b90} TCPHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper(DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002ed692c0 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(DB::AccessFlags) const @ 0x000000002ed6708a 6. ./build_docker/./src/Access/ContextAccess.cpp:724: DB::ContextAccess::checkAccess(DB::AccessFlags const&) const @ 0x000000002ed2afbd 7. ./build_docker/./src/Interpreters/Context.cpp:1398: void DB::Context::checkAccessImpl(DB::AccessFlags const&) const @ 0x000000002fc971fe 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:34: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e0ee4 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:107: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f308d6 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:21.638038 [ 23573 ] {1bf94f73-ba80-4d3e-acb1-94f1040bae8d} executeQuery: Code: 490. DB::Exception: Value cannot be represented as date because it's out of range: In scope SELECT fromModifiedJulianDay(CAST('9223372036854775807', 'Int64')). (CANNOT_FORMAT_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:56740) (comment: 02463_julian_day_ubsan.sql) (in query: SELECT fromModifiedJulianDay(9223372036854775807 :: Int64);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::OrdinalDate::init(long) @ 0x00000000193eecd7 5. DB::GregorianDate::GregorianDate(long) @ 0x00000000193ee3ce 6. DB::ExecutableFunctionFromModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b963ff6 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:21.638279 [ 23573 ] {1bf94f73-ba80-4d3e-acb1-94f1040bae8d} TCPHandler: Code: 490. DB::Exception: Value cannot be represented as date because it's out of range: In scope SELECT fromModifiedJulianDay(CAST('9223372036854775807', 'Int64')). (CANNOT_FORMAT_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::OrdinalDate::init(long) @ 0x00000000193eecd7 5. DB::GregorianDate::GregorianDate(long) @ 0x00000000193ee3ce 6. DB::ExecutableFunctionFromModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b963ff6 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:10:21.943134 [ 23573 ] {2da4578b-a785-4f81-abe4-f766457406b6} executeQuery: Code: 277. DB::Exception: Primary key (v) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:56818) (comment: 02462_match_regexp_pk.sql) (in query: SELECT count() FROM mt_match_pk WHERE match(v, '^a$|^b');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1623: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f415d8 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:21.943325 [ 23573 ] {2da4578b-a785-4f81-abe4-f766457406b6} TCPHandler: Code: 277. DB::Exception: Primary key (v) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000003224da23 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1623: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f415d8 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:22.256033 [ 14974 ] {6cc3873d-a257-4ec9-997d-35ccdf681699} PushingToViews: Trying to access table test_92eejde5.test_race_condition_mv_2 but it doesn't exist 2025.03.05 21:10:23.627941 [ 23600 ] {142c6dca-673b-4425-91e8-eb1a5ef3b05d} PushingToViews: Trying to access table test_92eejde5.test_race_condition_mv1_1 but it doesn't exist 2025.03.05 21:10:23.680722 [ 23587 ] {153a7055-0936-4d75-a20c-4de3193f97f6} executeQuery: Code: 252. DB::Exception: Too many parts (3 with average size of 157.00 B) in table 'test_re72a7fb.test (b672277d-49df-46a1-a7a7-c6c03dd98a05)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.3.12.76.altinitystable) (from [::1]:57278) (comment: 02458_relax_too_many_parts.sql) (in query: INSERT INTO test VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000032bee462 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000032b6f0db 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51656 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 9. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 10. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x0000000033579d62 11. ./contrib/llvm-project/libcxx/include/vector:537: DB::TCPHandler::processInsertQuery() @ 0x000000003349ec9c 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:23.680841 [ 23587 ] {153a7055-0936-4d75-a20c-4de3193f97f6} TCPHandler: Code: 252. DB::Exception: Too many parts (3 with average size of 157.00 B) in table 'test_re72a7fb.test (b672277d-49df-46a1-a7a7-c6c03dd98a05)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000032bee462 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000032b6f0db 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51656 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 9. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 10. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x0000000033579d62 11. ./contrib/llvm-project/libcxx/include/vector:537: DB::TCPHandler::processInsertQuery() @ 0x000000003349ec9c 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:23.701010 [ 23587 ] {3807e527-1d6c-43f7-8cf5-1d26904cade4} executeQuery: Code: 252. DB::Exception: Too many parts (3 with average size of 161.00 B) in table 'test_re72a7fb.test (b672277d-49df-46a1-a7a7-c6c03dd98a05)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.3.12.76.altinitystable) (from [::1]:57278) (comment: 02458_relax_too_many_parts.sql) (in query: INSERT INTO test VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000032bee462 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000032b6f0db 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51656 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 9. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 10. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x0000000033579d62 11. ./contrib/llvm-project/libcxx/include/vector:537: DB::TCPHandler::processInsertQuery() @ 0x000000003349ec9c 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:23.701096 [ 23587 ] {3807e527-1d6c-43f7-8cf5-1d26904cade4} TCPHandler: Code: 252. DB::Exception: Too many parts (3 with average size of 161.00 B) in table 'test_re72a7fb.test (b672277d-49df-46a1-a7a7-c6c03dd98a05)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000032bee462 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000032b6f0db 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51656 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 9. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 10. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x0000000033579d62 11. ./contrib/llvm-project/libcxx/include/vector:537: DB::TCPHandler::processInsertQuery() @ 0x000000003349ec9c 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:26.372424 [ 23582 ] {f65e4616-0c53-4613-9352-8e802b6b2e32} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.3.12.76.altinitystable) (from [::1]:57878) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:26.372618 [ 23582 ] {f65e4616-0c53-4613-9352-8e802b6b2e32} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:27.078272 [ 23587 ] {a042fead-b33e-4744-a4e6-198381cfeaa1} executeQuery: Code: 291. DB::Exception: Cannot log errors in path `/var/lib/clickhouse/user_files/../error_file`, because it is not inside `/var/lib/clickhouse/user_files/`: While executing File. (DATABASE_ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:57986) (comment: 02453_check_path_in_errors_logger.sql) (in query: select * from file(02453_data.jsonl, auto, 'x UInt32') settings input_format_allow_errors_num=1, input_format_record_errors_file_path='../error_file';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Processors/Formats/InputFormatErrorsLogger.cpp:40: DB::InputFormatErrorsLogger::InputFormatErrorsLogger(std::shared_ptr const&) @ 0x00000000335a8490 5. ./src/Processors/Formats/InputFormatErrorsLogger.h:48: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000] const&>(std::allocator, std::shared_ptr const&) @ 0x00000000334fd586 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr const&, void>(std::allocator const&, std::shared_ptr const&) @ 0x00000000334fd31e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: DB::FormatFactory::getInput(String const&, DB::ReadBuffer&, DB::Block const&, std::shared_ptr const&, unsigned long, std::optional const&, std::optional, std::optional, bool, DB::CompressionMethod, bool) const @ 0x00000000334e952a 8. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFileSource::generate() @ 0x00000000321e91e6 9. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:27.078561 [ 23587 ] {a042fead-b33e-4744-a4e6-198381cfeaa1} TCPHandler: Code: 291. DB::Exception: Cannot log errors in path `/var/lib/clickhouse/user_files/../error_file`, because it is not inside `/var/lib/clickhouse/user_files/`: While executing File. (DATABASE_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Processors/Formats/InputFormatErrorsLogger.cpp:40: DB::InputFormatErrorsLogger::InputFormatErrorsLogger(std::shared_ptr const&) @ 0x00000000335a8490 5. ./src/Processors/Formats/InputFormatErrorsLogger.h:48: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000] const&>(std::allocator, std::shared_ptr const&) @ 0x00000000334fd586 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr const&, void>(std::allocator const&, std::shared_ptr const&) @ 0x00000000334fd31e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: DB::FormatFactory::getInput(String const&, DB::ReadBuffer&, DB::Block const&, std::shared_ptr const&, unsigned long, std::optional const&, std::optional, std::optional, bool, DB::CompressionMethod, bool) const @ 0x00000000334e952a 8. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFileSource::generate() @ 0x00000000321e91e6 9. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:29.117565 [ 23610 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:42008) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:29.117802 [ 23610 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-1} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:29.397328 [ 12525 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:42170) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:29.397544 [ 12525 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-2} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:29.676428 [ 12525 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:42230) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:29.676609 [ 12525 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-3} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:29.982781 [ 23590 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-4} executeQuery: Code: 394. DB::Exception: Query '02450_kill_distributed_query_deadlock_test_hq8u5jh1-4' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:42330) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316feefb 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:29.983133 [ 23590 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-4} TCPHandler: Code: 394. DB::Exception: Query '02450_kill_distributed_query_deadlock_test_hq8u5jh1-4' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316feefb 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:30.044500 [ 23610 ] {cc2c5849-c653-41c0-8cd5-bff8dd2c78f4} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_0169wodn.view (7c61e487-1f26-4a6e-bc68-a3f25fa17704), because some tables depend on it: test_0169wodn.dict. (HAVE_DEPENDENT_OBJECTS) (version 24.3.12.76.altinitystable) (from [::1]:42284) (comment: 02449_check_dependencies_and_table_shutdown.sql) (in query: DROP TABLE view;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000002fda7392 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1456: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9b344 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9ba54 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000307f634b 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:103: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000307f3e26 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000307f29e2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:30.044687 [ 23610 ] {cc2c5849-c653-41c0-8cd5-bff8dd2c78f4} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_0169wodn.view (7c61e487-1f26-4a6e-bc68-a3f25fa17704), because some tables depend on it: test_0169wodn.dict. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000002fda7392 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1456: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9b344 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9ba54 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000307f634b 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:103: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000307f3e26 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000307f29e2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:30.055569 [ 23610 ] {e3f235ff-9cbf-45f7-ba24-89de143d503b} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_0169wodn.dict (84a61d84-13fe-4d65-b32b-9c2943d8d4af), because some tables depend on it: test_0169wodn.`table`. (HAVE_DEPENDENT_OBJECTS) (version 24.3.12.76.altinitystable) (from [::1]:42284) (comment: 02449_check_dependencies_and_table_shutdown.sql) (in query: DROP DICTIONARY dict;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000002fda7392 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1456: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9b344 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9ba54 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000307f634b 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:103: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000307f3e26 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000307f29e2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:30.055727 [ 23610 ] {e3f235ff-9cbf-45f7-ba24-89de143d503b} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_0169wodn.dict (84a61d84-13fe-4d65-b32b-9c2943d8d4af), because some tables depend on it: test_0169wodn.`table`. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000002fda7392 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1456: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9b344 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9ba54 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000307f634b 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:103: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000307f3e26 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000307f29e2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:30.440841 [ 23621 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-5} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:42436) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:30.441484 [ 23621 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-5} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:30.479048 [ 1369 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:30.517637 [ 1369 ] {} test_aubytgly.rmt2 (8311e063-a01b-48d0-8a3e-af008813a93e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:30.848554 [ 730 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-6} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:42558) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:30.848795 [ 730 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-6} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:31.285939 [ 23621 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:42618) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:31.286230 [ 23621 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-7} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:31.343881 [ 1192 ] {} test_aubytgly.rmt2 (ReplicatedMergeTreeCleanupThread): Will mark replica 1 as lost, because it has stale log pointer: log-0000000001 2025.03.05 21:10:31.759635 [ 23498 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-8} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:42768) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:31.759983 [ 23498 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-8} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:32.024416 [ 22860 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-9} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:42880) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:32.024606 [ 22860 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-9} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:32.483587 [ 23498 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-10} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:42934) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:32.483861 [ 23498 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-10} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:33.004464 [ 23590 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-11} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:43040) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:33.004754 [ 23590 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-11} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:33.273518 [ 14920 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-12} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:43258) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:33.273718 [ 14920 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-12} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:33.553368 [ 22860 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-13} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:43286) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:33.553599 [ 22860 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-13} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:33.979302 [ 1658 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-14} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:43318) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:33.979694 [ 1658 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-14} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:34.280625 [ 22860 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-15} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:43414) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:34.280848 [ 22860 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-15} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:34.577288 [ 1658 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-16} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:43582) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:34.577607 [ 1658 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-16} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:34.857054 [ 14974 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-17} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:43646) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:34.857312 [ 14974 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-17} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:35.047132 [ 1658 ] {0acff92f-8e23-4bf8-beab-c407e074c5e3} executeQuery: Code: 305. DB::Exception: There is a local database rdb_test_ij69dtea, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED) (version 24.3.12.76.altinitystable) (from [::1]:43662) (comment: 02447_drop_database_replica.sh) (in query: system drop database replica 's1|r1' from database rdb_test_ij69dtea), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x00000000317702fb 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1064: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x000000003175fadd 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:35.047477 [ 1658 ] {0acff92f-8e23-4bf8-beab-c407e074c5e3} TCPHandler: Code: 305. DB::Exception: There is a local database rdb_test_ij69dtea, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x00000000317702fb 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1064: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x000000003175fadd 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:35.142089 [ 1658 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-18} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:43674) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:35.142379 [ 1658 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-18} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:35.251788 [ 1658 ] {935e292c-8fa8-4b84-84bd-bd82009c04ef} executeQuery: Code: 305. DB::Exception: There is a local database rdb_test_ij69dtea, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED) (version 24.3.12.76.altinitystable) (from [::1]:43700) (comment: 02447_drop_database_replica.sh) (in query: system drop database replica 'r1' from shard 's1' from database rdb_test_ij69dtea), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x00000000317702fb 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1064: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x000000003175fadd 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:35.252020 [ 1658 ] {935e292c-8fa8-4b84-84bd-bd82009c04ef} TCPHandler: Code: 305. DB::Exception: There is a local database rdb_test_ij69dtea, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x00000000317702fb 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1064: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x000000003175fadd 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:35.432056 [ 14974 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-19} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:43722) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:35.432389 [ 14974 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-19} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:35.486614 [ 1658 ] {85c7caa7-d2f5-42c2-812d-a275de3eb5bc} executeQuery: Code: 305. DB::Exception: There is a local database rdb_test_ij69dtea, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED) (version 24.3.12.76.altinitystable) (from [::1]:43760) (comment: 02447_drop_database_replica.sh) (in query: system drop database replica 's1|r1' from zkpath '/test/test_ij69dtea/rdb'), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x00000000317702fb 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000031760502 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:35.487077 [ 1658 ] {85c7caa7-d2f5-42c2-812d-a275de3eb5bc} TCPHandler: Code: 305. DB::Exception: There is a local database rdb_test_ij69dtea, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x00000000317702fb 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000031760502 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:35.517436 [ 22866 ] {5ccb96fa-b0bb-468a-bdca-5a3a22885907} InterpreterSystemQuery: SYNC REPLICA test_aubytgly.rmt2 (8311e063-a01b-48d0-8a3e-af008813a93e): Timed out. 2025.03.05 21:10:35.535891 [ 22866 ] {5ccb96fa-b0bb-468a-bdca-5a3a22885907} executeQuery: Code: 159. DB::Exception: SYNC REPLICA test_aubytgly.rmt2 (8311e063-a01b-48d0-8a3e-af008813a93e): command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:42498) (comment: 02448_clone_replica_lost_part.sql) (in query: system sync replica rmt2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000031763d7f 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:670: DB::InterpreterSystemQuery::execute() @ 0x000000003174e92b 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:35.536128 [ 22866 ] {5ccb96fa-b0bb-468a-bdca-5a3a22885907} TCPHandler: Code: 159. DB::Exception: SYNC REPLICA test_aubytgly.rmt2 (8311e063-a01b-48d0-8a3e-af008813a93e): command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000031763d7f 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:670: DB::InterpreterSystemQuery::execute() @ 0x000000003174e92b 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:35.567853 [ 1061 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Will mimic 2 2025.03.05 21:10:35.659678 [ 1355 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_7_0&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_7_0&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:35.659881 [ 1355 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:35.665892 [ 1362 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_7_0&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_7_0&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:35.666091 [ 1362 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:35.666750 [ 1376 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_8_8_0&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_8_8_0&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:35.666939 [ 1376 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:35.673161 [ 1364 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_8_8_0&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_8_8_0&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:35.673281 [ 1371 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_7_0&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_7_0&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:35.673445 [ 1364 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_8_8_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:35.673803 [ 1371 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_7_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:35.738859 [ 23612 ] {ab67123d-297f-4a0c-a383-768e4ae11ac7} executeQuery: Code: 305. DB::Exception: There is a local database rdb_test_ij69dtea, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED) (version 24.3.12.76.altinitystable) (from [::1]:43884) (comment: 02447_drop_database_replica.sh) (in query: system drop database replica 's1|r1' from zkpath '/test/test_ij69dtea/rdb/'), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x00000000317702fb 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000031760502 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:35.739112 [ 23612 ] {ab67123d-297f-4a0c-a383-768e4ae11ac7} TCPHandler: Code: 305. DB::Exception: There is a local database rdb_test_ij69dtea, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x00000000317702fb 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000031760502 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:35.920291 [ 1658 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-20} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:43894) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:35.920537 [ 1658 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-20} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:35.945508 [ 1658 ] {5f2a2921-db5d-45c6-a1b4-e9baa977e005} executeQuery: Code: 305. DB::Exception: There is a local database rdb_test_ij69dtea, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED) (version 24.3.12.76.altinitystable) (from [::1]:43992) (comment: 02447_drop_database_replica.sh) (in query: system drop database replica 'r1' from shard 's1' from zkpath '/test/test_ij69dtea/rdb/'), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x00000000317702fb 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000031760502 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:35.945803 [ 1658 ] {5f2a2921-db5d-45c6-a1b4-e9baa977e005} TCPHandler: Code: 305. DB::Exception: There is a local database rdb_test_ij69dtea, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x00000000317702fb 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000031760502 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:36.160472 [ 23642 ] {45ae2cf2-cac5-4e23-bbcc-91ecd380e0b8} executeQuery: Code: 36. DB::Exception: Path /test/test_ij69dtea does not look like a path of Replicated database. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44048) (comment: 02447_drop_database_replica.sh) (in query: system drop database replica 's1|r1' from zkpath '/test/test_ij69dtea/'), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1269: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x000000002f7a1799 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1104: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x000000003176057e 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:36.160820 [ 23642 ] {45ae2cf2-cac5-4e23-bbcc-91ecd380e0b8} TCPHandler: Code: 36. DB::Exception: Path /test/test_ij69dtea does not look like a path of Replicated database. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1269: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x000000002f7a1799 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1104: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x000000003176057e 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:36.215139 [ 23639 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-21} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:44058) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:36.215381 [ 23639 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-21} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:36.311532 [ 1329 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:36.336518 [ 1329 ] {} ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae::all_7_8_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:169: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x0000000032f41b55 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032f3f3e0 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000032f3c41e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032addf0f 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032adec9e 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:36.336634 [ 1329 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae::all_7_8_1}: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:169: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x0000000032f41b55 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032f3f3e0 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000032f3c41e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032addf0f 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032adec9e 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:36.338980 [ 1374 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:36.339247 [ 1374 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:36.378399 [ 23639 ] {bfef5933-8d76-45ba-8830-a0acc358464b} executeQuery: Code: 36. DB::Exception: Replica s2|r1 does not exist (database path: /test/test_ij69dtea/rdb). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44088) (comment: 02447_drop_database_replica.sh) (in query: system drop database replica 's2|r1' from zkpath '/test/test_ij69dtea/rdb'), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x000000002497856a 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x000000002f7a1453 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1104: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x000000003176057e 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:36.378795 [ 23639 ] {bfef5933-8d76-45ba-8830-a0acc358464b} TCPHandler: Code: 36. DB::Exception: Replica s2|r1 does not exist (database path: /test/test_ij69dtea/rdb). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x000000002497856a 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x000000002f7a1453 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1104: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x000000003176057e 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:36.603334 [ 23642 ] {09405825-b7a6-4f11-afb2-cb0d1ac085c8} executeQuery: Code: 36. DB::Exception: Replica r1|s1 does not exist (database path: /test/test_ij69dtea/rdb). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44130) (comment: 02447_drop_database_replica.sh) (in query: system drop database replica 's1' from shard 'r1' from zkpath '/test/test_ij69dtea/rdb'), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x000000002497856a 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x000000002f7a1453 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1104: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x000000003176057e 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:36.603566 [ 23642 ] {09405825-b7a6-4f11-afb2-cb0d1ac085c8} TCPHandler: Code: 36. DB::Exception: Replica r1|s1 does not exist (database path: /test/test_ij69dtea/rdb). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x000000002497856a 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x000000002f7a1453 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1104: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x000000003176057e 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:36.637350 [ 23639 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-22} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:44114) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:36.637590 [ 23639 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-22} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:36.821853 [ 23642 ] {4ddab003-2eb0-47bc-8fa0-991120962626} executeQuery: Code: 36. DB::Exception: Replica s1|s1|r1 does not exist (database path: /test/test_ij69dtea/rdb). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44178) (comment: 02447_drop_database_replica.sh) (in query: system drop database replica 's1|r1' from shard 's1' from zkpath '/test/test_ij69dtea/rdb'), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x000000002497856a 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x000000002f7a1453 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1104: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x000000003176057e 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:36.822097 [ 23642 ] {4ddab003-2eb0-47bc-8fa0-991120962626} TCPHandler: Code: 36. DB::Exception: Replica s1|s1|r1 does not exist (database path: /test/test_ij69dtea/rdb). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x000000002497856a 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x000000002f7a1453 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1104: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x000000003176057e 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:37.070786 [ 23642 ] {e8ec8502-893a-4879-946d-b85209ed7634} executeQuery: Code: 36. DB::Exception: Invalid replica name, '/' is not allowed: s2/r1. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44284) (comment: 02447_drop_database_replica.sh) (in query: system drop database replica 's2/r1' from zkpath '/test/test_ij69dtea/rdb'), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1260: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x000000002f7a1844 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1104: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x000000003176057e 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:37.071108 [ 23642 ] {e8ec8502-893a-4879-946d-b85209ed7634} TCPHandler: Code: 36. DB::Exception: Invalid replica name, '/' is not allowed: s2/r1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1260: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x000000002f7a1844 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1104: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x000000003176057e 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:37.158313 [ 23639 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-23} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:44212) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:37.158645 [ 23639 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-23} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:37.287361 [ 1347 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:37.287668 [ 1347 ] {} ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae::all_7_8_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:169: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x0000000032f41b55 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032f3f3e0 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000032f3c41e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032addf0f 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032adec9e 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:37.287828 [ 1347 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae::all_7_8_1}: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:169: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x0000000032f41b55 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032f3f3e0 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000032f3c41e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032addf0f 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032adec9e 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:37.290664 [ 1376 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:37.290993 [ 1376 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_7_8_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:37.353888 [ 1858 ] {} DDLWorker(rdb_test_ij69dtea_2): Error on initialization of rdb_test_ij69dtea_2: Code: 57. DB::Exception: Directory for table data store/0e9/0e914386-d15b-4240-a6e1-85eb43da6bbf/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cef63 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002f79b712 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002f790b23 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002f7c06e8 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002f7bcc21 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1141: DB::DDLWorker::runMainThread() @ 0x000000002fd4bf30 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:37.440075 [ 23621 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-24} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:44424) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:37.440334 [ 23621 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-24} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:37.507685 [ 11290 ] {} DDLWorker(rdb_test_ij69dtea_3): Error on initialization of rdb_test_ij69dtea_3: Code: 57. DB::Exception: Directory for table data store/0e9/0e914386-d15b-4240-a6e1-85eb43da6bbf/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cef63 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002f79b712 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002f790b23 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002f7c06e8 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002f7bcc21 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1141: DB::DDLWorker::runMainThread() @ 0x000000002fd4bf30 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:37.721076 [ 23621 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-25} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:44486) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:37.721324 [ 23621 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-25} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:38.017530 [ 23621 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-26} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:44528) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:38.017784 [ 23621 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-26} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:38.082790 [ 730 ] {ff94bf5d-05c3-4b3e-a6a2-72551764b19b} executeQuery: Code: 36. DB::Exception: Replica s1|r1 is active, cannot drop it (database path: /test/test_ij69dtea/rdb). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44558) (comment: 02447_drop_database_replica.sh) (in query: system drop database replica 's1|r1' from database rdb_test_ij69dtea_2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x000000002497856a 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x000000002f7a19a9 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1069: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x000000003175fbb6 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:38.083158 [ 730 ] {ff94bf5d-05c3-4b3e-a6a2-72551764b19b} TCPHandler: Code: 36. DB::Exception: Replica s1|r1 is active, cannot drop it (database path: /test/test_ij69dtea/rdb). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x000000002497856a 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x000000002f7a19a9 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1069: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x000000003175fbb6 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:667: DB::InterpreterSystemQuery::execute() @ 0x000000003174eb3b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:38.303000 [ 23621 ] {c91e916f-e30e-44ca-b447-0c88136975ed} executeQuery: Code: 159. DB::Exception: Distributed DDL task /test/test_ij69dtea/rdb/log/query-0000000005 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 2 are inactive). They are going to execute the query in background. Was waiting for 0 seconds. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:44616) (comment: 02447_drop_database_replica.sh) (in query: create table rdb_test_ij69dtea.t2 (n int) engine=Log), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:38.312508 [ 730 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-27} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:44642) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000033558860 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 8. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 10. ? @ 0x00007fe1df9bbac3 11. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:38.312543 [ 23621 ] {c91e916f-e30e-44ca-b447-0c88136975ed} TCPHandler: Code: 159. DB::Exception: Distributed DDL task /test/test_ij69dtea/rdb/log/query-0000000005 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 2 are inactive). They are going to execute the query in background. Was waiting for 0 seconds. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:38.312839 [ 730 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-27} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000033558860 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 8. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 10. ? @ 0x00007fe1df9bbac3 11. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:38.548234 [ 23577 ] {fcd93a5e-4c10-4585-99c0-895b46a404df} executeQuery: Code: 159. DB::Exception: Distributed DDL task /test/test_ij69dtea/rdb/log/query-0000000006 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 2 are inactive). They are going to execute the query in background. Was waiting for 0 seconds. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:44762) (comment: 02447_drop_database_replica.sh) (in query: create table rdb_test_ij69dtea.t3 (n int) engine=Log), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:38.548585 [ 23577 ] {fcd93a5e-4c10-4585-99c0-895b46a404df} TCPHandler: Code: 159. DB::Exception: Distributed DDL task /test/test_ij69dtea/rdb/log/query-0000000006 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 2 are inactive). They are going to execute the query in background. Was waiting for 0 seconds. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:38.613733 [ 23621 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-28} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:44778) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:38.614027 [ 23621 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-28} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:38.877645 [ 23590 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-29} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:44890) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:38.877910 [ 23590 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-29} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:39.156508 [ 23555 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-30} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:33890) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:39.156712 [ 23555 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-30} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:39.282157 [ 1155 ] {} test_aubytgly.rmt1 (ReplicatedMergeTreeCleanupThread): Will mark replica 2 as lost, because it has stale log pointer: log-0000000010 2025.03.05 21:10:39.429860 [ 23621 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-31} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:33906) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:39.430091 [ 23621 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-31} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:39.726965 [ 23619 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-32} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:33992) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:39.727201 [ 23619 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-32} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:40.204576 [ 14920 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-33} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:34188) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:40.204862 [ 14920 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-33} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:40.484355 [ 12524 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-34} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:34246) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:40.484595 [ 12524 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-34} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:40.940520 [ 14920 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-35} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:34282) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:40.940776 [ 14920 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-35} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:41.319738 [ 12524 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-36} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:34422) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:41.320153 [ 12524 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-36} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:41.427752 [ 23612 ] {7f8b9679-7aeb-4187-bfda-272d14374ef4} PushingToViews: Trying to access table test_92eejde5.test_race_condition_mv_1 but it doesn't exist 2025.03.05 21:10:41.633312 [ 23587 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-37} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:34536) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:41.633608 [ 23587 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-37} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:42.055056 [ 23628 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-38} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:34578) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:42.055322 [ 23628 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-38} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:42.329699 [ 23628 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-39} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:34626) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:42.329907 [ 23628 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-39} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:42.358306 [ 1858 ] {} DDLWorker(rdb_test_ij69dtea_2): Error on initialization of rdb_test_ij69dtea_2: Code: 57. DB::Exception: Directory for table data store/0ee/0ee45a3d-ecac-4bbf-848e-4fb6ef596d99/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cef63 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002f79b712 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002f790b23 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002f7c06e8 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002f7bcc21 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1141: DB::DDLWorker::runMainThread() @ 0x000000002fd4bf30 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:42.657683 [ 23628 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-40} executeQuery: Code: 394. DB::Exception: Query '02450_kill_distributed_query_deadlock_test_hq8u5jh1-40' is killed in pending state. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:34752) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316feefb 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:42.657937 [ 23628 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-40} TCPHandler: Code: 394. DB::Exception: Query '02450_kill_distributed_query_deadlock_test_hq8u5jh1-40' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316feefb 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:42.703737 [ 22866 ] {3b6a7957-b499-4d1a-b348-a035ddc42d41} InterpreterSystemQuery: SYNC REPLICA test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Timed out. 2025.03.05 21:10:42.704223 [ 22866 ] {3b6a7957-b499-4d1a-b348-a035ddc42d41} executeQuery: Code: 159. DB::Exception: SYNC REPLICA test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:42498) (comment: 02448_clone_replica_lost_part.sql) (in query: -- check that entry was not removed from the queue (part is not lost) system sync replica rmt1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000031763d7f 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:670: DB::InterpreterSystemQuery::execute() @ 0x000000003174e92b 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:42.704395 [ 22866 ] {3b6a7957-b499-4d1a-b348-a035ddc42d41} TCPHandler: Code: 159. DB::Exception: SYNC REPLICA test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000031763d7f 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:670: DB::InterpreterSystemQuery::execute() @ 0x000000003174e92b 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:42.734946 [ 1199 ] {} test_aubytgly.rmt2 (8311e063-a01b-48d0-8a3e-af008813a93e): Will mimic 1 2025.03.05 21:10:42.909659 [ 23642 ] {f4ea91e0-4c7e-41ef-a541-1cda3ea9dc40} DatabaseReplicated (rdb_test_ij69dtea_3): Database rdb_test_ij69dtea_3 exists locally, but its replica does not exist in ZooKeeper (/test/test_ij69dtea/rdb/replicas/s2|r1). Assuming it was dropped, will not try to start it up 2025.03.05 21:10:42.938297 [ 11389 ] {} DDLWorker(rdb_test_wmtz716k_2): Error on initialization of rdb_test_wmtz716k_2: Code: 57. DB::Exception: Directory for table data store/8cb/8cb9be4f-3d92-4e66-9cf9-a4887ed01d67/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cef63 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002f79b712 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002f790b23 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002f7c06e8 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002f7bcc21 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1141: DB::DDLWorker::runMainThread() @ 0x000000002fd4bf30 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:43.100658 [ 23642 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-41} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:34916) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:43.100902 [ 23642 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-41} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:43.118185 [ 11405 ] {} DDLWorker(rdb_test_wmtz716k_3): Error on initialization of rdb_test_wmtz716k_3: Code: 57. DB::Exception: Directory for table data store/8cb/8cb9be4f-3d92-4e66-9cf9-a4887ed01d67/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cef63 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002f79b712 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002f790b23 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002f7c06e8 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002f7bcc21 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1141: DB::DDLWorker::runMainThread() @ 0x000000002fd4bf30 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:43.146803 [ 23610 ] {260aa93f-7862-4e12-b2ac-572ab769e963} executeQuery: Code: 225. DB::Exception: Database is in readonly mode, because it cannot connect to ZooKeeper. (NO_ZOOKEEPER) (version 24.3.12.76.altinitystable) (from [::1]:34950) (comment: 02447_drop_database_replica.sh) (in query: create table rdb_test_ij69dtea_3.t2 as system.query_log), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:771: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f78811f 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1c55 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:43.147418 [ 23610 ] {260aa93f-7862-4e12-b2ac-572ab769e963} TCPHandler: Code: 225. DB::Exception: Database is in readonly mode, because it cannot connect to ZooKeeper. (NO_ZOOKEEPER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:771: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f78811f 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1c55 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:43.335664 [ 23642 ] {17bc2bad-165d-4481-aaba-b48176023447} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000006 */ ALTER TABLE rdb_test_wmtz716k.mt DROP PARTITION ID 'all', ADD COLUMN `m` int), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 11. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:43.337529 [ 23642 ] {17bc2bad-165d-4481-aaba-b48176023447} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:34996) (comment: 02445_replicated_db_alter_partition.sh) (in query: alter table rdb_test_wmtz716k.mt drop partition id 'all', add column m int), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 11. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:43.337790 [ 23642 ] {17bc2bad-165d-4481-aaba-b48176023447} TCPHandler: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 11. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:43.383137 [ 5753 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-42} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:35020) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:43.383337 [ 5753 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-42} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:43.577501 [ 23642 ] {363a8751-6b36-4a8c-8fcc-90b0c0b413ea} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000007 */ ALTER TABLE rdb_test_wmtz716k.rmt DROP PARTITION ID 'all', ADD COLUMN `m` int), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:847: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002fd66c40 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:656: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5e951 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:43.580166 [ 23642 ] {363a8751-6b36-4a8c-8fcc-90b0c0b413ea} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:35048) (comment: 02445_replicated_db_alter_partition.sh) (in query: alter table rdb_test_wmtz716k.rmt drop partition id 'all', add column m int), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:847: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002fd66c40 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:656: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5e951 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:43.580518 [ 23642 ] {363a8751-6b36-4a8c-8fcc-90b0c0b413ea} TCPHandler: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:847: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002fd66c40 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:656: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5e951 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:43.673690 [ 23587 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-43} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:35082) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:43.673961 [ 23587 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-43} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:43.807333 [ 23642 ] {b34d73b5-f471-4c47-9bf2-33a2c7559fcf} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000008 */ ALTER TABLE rdb_test_wmtz716k.mt DROP PARTITION ID 'all', UPDATE n = 2 WHERE 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 11. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:43.808663 [ 23642 ] {b34d73b5-f471-4c47-9bf2-33a2c7559fcf} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:35128) (comment: 02445_replicated_db_alter_partition.sh) (in query: alter table rdb_test_wmtz716k.mt drop partition id 'all', update n = 2 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 11. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:43.809041 [ 23642 ] {b34d73b5-f471-4c47-9bf2-33a2c7559fcf} TCPHandler: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 11. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:43.990325 [ 5753 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-44} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:35156) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:43.990580 [ 5753 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-44} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:44.042490 [ 5753 ] {ae22d735-a8a6-428c-ab2d-b2d009ccbf5f} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000009 */ ALTER TABLE rdb_test_wmtz716k.rmt DROP PARTITION ID 'all', UPDATE n = 2 WHERE 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:847: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002fd66c40 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:656: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5e951 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:44.044694 [ 5753 ] {ae22d735-a8a6-428c-ab2d-b2d009ccbf5f} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:35220) (comment: 02445_replicated_db_alter_partition.sh) (in query: alter table rdb_test_wmtz716k.rmt drop partition id 'all', update n = 2 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:847: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002fd66c40 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:656: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5e951 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:44.045043 [ 5753 ] {ae22d735-a8a6-428c-ab2d-b2d009ccbf5f} TCPHandler: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:847: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002fd66c40 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:656: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5e951 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:44.265528 [ 23586 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-45} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:35308) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:44.265726 [ 23586 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-45} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:44.540618 [ 22858 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-46} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:35326) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:44.540903 [ 22858 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-46} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:44.809021 [ 23606 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-47} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:35372) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:44.809318 [ 23606 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-47} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:45.312700 [ 23586 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-48} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:35460) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:45.313112 [ 23586 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-48} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:45.500428 [ 1370 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:45.500794 [ 1370 ] {} test_aubytgly.rmt2 (8311e063-a01b-48d0-8a3e-af008813a93e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:45.510338 [ 1376 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:45.510735 [ 1376 ] {} test_aubytgly.rmt2 (8311e063-a01b-48d0-8a3e-af008813a93e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:45.515904 [ 1369 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:45.516260 [ 1369 ] {} test_aubytgly.rmt2 (8311e063-a01b-48d0-8a3e-af008813a93e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:45.523566 [ 1340 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:45.523929 [ 1340 ] {} test_aubytgly.rmt2 (8311e063-a01b-48d0-8a3e-af008813a93e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:45.529339 [ 1355 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:45.529715 [ 1355 ] {} test_aubytgly.rmt2 (8311e063-a01b-48d0-8a3e-af008813a93e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:45.535732 [ 1363 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:45.536000 [ 1363 ] {} test_aubytgly.rmt2 (8311e063-a01b-48d0-8a3e-af008813a93e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:45.590720 [ 23619 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-49} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:35612) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:45.591052 [ 23619 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-49} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:45.857445 [ 23619 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-50} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:35642) (comment: 02450_kill_distributed_query_deadlock.sh) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:45.857648 [ 23619 ] {02450_kill_distributed_query_deadlock_test_hq8u5jh1-50} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:45.979239 [ 1344 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:45.979693 [ 1344 ] {} 8311e063-a01b-48d0-8a3e-af008813a93e::all_12_12_0_13 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:169: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x0000000032f41b55 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032f3f3e0 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000032f3c41e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032addf0f 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032adec9e 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:45.979936 [ 1344 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8311e063-a01b-48d0-8a3e-af008813a93e::all_12_12_0_13}: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:169: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x0000000032f41b55 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032f3f3e0 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000032f3c41e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032addf0f 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032adec9e 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:45.982277 [ 1374 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:45.982523 [ 1374 ] {} test_aubytgly.rmt2 (8311e063-a01b-48d0-8a3e-af008813a93e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:46.684077 [ 1341 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:46.684421 [ 1341 ] {} 8311e063-a01b-48d0-8a3e-af008813a93e::all_12_12_0_13 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:169: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x0000000032f41b55 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032f3f3e0 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000032f3c41e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032addf0f 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032adec9e 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:46.684583 [ 1341 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8311e063-a01b-48d0-8a3e-af008813a93e::all_12_12_0_13}: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:169: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x0000000032f41b55 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032f3f3e0 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000032f3c41e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032addf0f 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032adec9e 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:46.686334 [ 1369 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:46.686549 [ 1369 ] {} test_aubytgly.rmt2 (8311e063-a01b-48d0-8a3e-af008813a93e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:47.157197 [ 1355 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:47.157441 [ 1355 ] {} test_4g3bonov.rmt2 (1886af2b-3569-4855-bfe7-b02516de073f): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:47.181532 [ 1372 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:47.181574 [ 1361 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_1_1_0&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_1_1_0&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:47.181751 [ 1372 ] {} test_4g3bonov.rmt2 (1886af2b-3569-4855-bfe7-b02516de073f): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:47.181802 [ 1361 ] {} test_4g3bonov.rmt2 (1886af2b-3569-4855-bfe7-b02516de073f): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:47.188905 [ 1343 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:47.189247 [ 1343 ] {} 8311e063-a01b-48d0-8a3e-af008813a93e::all_12_12_0_13 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:169: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x0000000032f41b55 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032f3f3e0 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000032f3c41e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032addf0f 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032adec9e 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:47.189403 [ 1343 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8311e063-a01b-48d0-8a3e-af008813a93e::all_12_12_0_13}: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:169: DB::ReplicatedMergeMutateTaskBase::executeImpl()::$_1::operator()(bool) const @ 0x0000000032f41b55 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032f3f3e0 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000032f3c41e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032addf0f 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032adec9e 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:47.192551 [ 1376 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:47.192849 [ 1376 ] {} test_aubytgly.rmt2 (8311e063-a01b-48d0-8a3e-af008813a93e): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F1&part=all_12_12_0_13&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:47.210100 [ 1369 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:47.210364 [ 1369 ] {} test_4g3bonov.rmt2 (1886af2b-3569-4855-bfe7-b02516de073f): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:47.210389 [ 1357 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_1_1_0&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_1_1_0&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:10:47.210606 [ 1357 ] {} test_4g3bonov.rmt2 (1886af2b-3569-4855-bfe7-b02516de073f): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_4g3bonov%2F02438%2Freplicas%2F1&part=all_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:47.564869 [ 23597 ] {066ffb80-4899-4952-b587-c81a7dcf7ea5} executeQuery: Code: 159. DB::Exception: Distributed DDL task /test/test_wmtz716k/rdb/log/query-0000000010 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.308006919 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:35294) (comment: 02445_replicated_db_alter_partition.sh) (in query: delete from rdb_test_wmtz716k.mt where n=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:47.565096 [ 23597 ] {066ffb80-4899-4952-b587-c81a7dcf7ea5} TCPHandler: Code: 159. DB::Exception: Distributed DDL task /test/test_wmtz716k/rdb/log/query-0000000010 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.308006919 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:47.698975 [ 777 ] {} test_aubytgly.rmt2 (ReplicatedMergeTreeCleanupThread): Will mark replica 1 as lost, because it has stale log pointer: log-0000000019 2025.03.05 21:10:47.913391 [ 23611 ] {27431147-08b0-48de-8abd-fdae604480e2} PushingToViews: Trying to access table test_92eejde5.test_race_condition_mv1_2 but it doesn't exist 2025.03.05 21:10:47.941707 [ 11389 ] {} DDLWorker(rdb_test_wmtz716k_2): Error on initialization of rdb_test_wmtz716k_2: Code: 57. DB::Exception: Directory for table data store/8cb/8cb9be4f-3d92-4e66-9cf9-a4887ed01d67/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cef63 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002f79b712 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002f790b23 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002f7c06e8 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002f7bcc21 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1141: DB::DDLWorker::runMainThread() @ 0x000000002fd4bf30 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:48.123322 [ 11405 ] {} DDLWorker(rdb_test_wmtz716k_3): Error on initialization of rdb_test_wmtz716k_3: Code: 57. DB::Exception: Directory for table data store/8cb/8cb9be4f-3d92-4e66-9cf9-a4887ed01d67/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cef63 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002f79b712 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002f790b23 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002f7c06e8 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002f7bcc21 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1141: DB::DDLWorker::runMainThread() @ 0x000000002fd4bf30 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:48.193552 [ 23642 ] {2b6e6f27-93e7-4294-854c-1f3165919979} DatabaseReplicated (rdb_test_ij69dtea_2): Database rdb_test_ij69dtea_2 exists locally, but its replica does not exist in ZooKeeper (/test/test_ij69dtea/rdb/replicas/s1|r2). Assuming it was dropped, will not try to start it up 2025.03.05 21:10:48.388290 [ 23610 ] {f0d5c3d0-87ed-4ac8-a0b4-ee07399d7b67} executeQuery: Code: 225. DB::Exception: Database is in readonly mode, because it cannot connect to ZooKeeper. (NO_ZOOKEEPER) (version 24.3.12.76.altinitystable) (from [::1]:36252) (comment: 02447_drop_database_replica.sh) (in query: create table rdb_test_ij69dtea_2.t2 as system.query_log), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:771: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f78811f 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1c55 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:48.388721 [ 23610 ] {f0d5c3d0-87ed-4ac8-a0b4-ee07399d7b67} TCPHandler: Code: 225. DB::Exception: Database is in readonly mode, because it cannot connect to ZooKeeper. (NO_ZOOKEEPER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:771: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f78811f 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1c55 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:49.048098 [ 23611 ] {ab3d4ee5-e892-437a-ac0f-2b9e1b3760f4} DatabaseReplicated (rdb_test_ij69dtea): Database rdb_test_ij69dtea exists locally, but its replica does not exist in ZooKeeper (/test/test_ij69dtea/rdb/replicas/s1|r1). Assuming it was dropped, will not try to start it up 2025.03.05 21:10:49.271407 [ 730 ] {fd7895a8-a1ec-4768-b31a-3c99117b25bc} executeQuery: Code: 225. DB::Exception: Database is in readonly mode, because it cannot connect to ZooKeeper. (NO_ZOOKEEPER) (version 24.3.12.76.altinitystable) (from [::1]:46152) (comment: 02447_drop_database_replica.sh) (in query: create table rdb_test_ij69dtea.t2 as system.query_log), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:771: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f78811f 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1c55 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:49.271740 [ 730 ] {fd7895a8-a1ec-4768-b31a-3c99117b25bc} TCPHandler: Code: 225. DB::Exception: Database is in readonly mode, because it cannot connect to ZooKeeper. (NO_ZOOKEEPER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:771: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f78811f 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1c55 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:49.413622 [ 1355 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_8_8_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:49.416878 [ 1371 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_9_9_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:49.663979 [ 23606 ] {cce90dd9-253c-4f47-ac88-cc978efccabc} executeQuery: Code: 60. DB::Exception: Table db_test_o52u1j0s.test does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:46260) (comment: 02437_drop_mv_restart_replicas.sh) (in query: INSERT INTO db_test_o52u1j0s.test SELECT 'case1', number%3, rand() FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:49.664433 [ 23606 ] {cce90dd9-253c-4f47-ac88-cc978efccabc} TCPHandler: Code: 60. DB::Exception: Table db_test_o52u1j0s.test does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:49.748950 [ 1355 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_13_13_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:50.093163 [ 1370 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_17_17_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:50.093352 [ 1340 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_18_18_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:50.093872 [ 1340 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_18_18_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:50.103812 [ 1364 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_19_19_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:50.131716 [ 23619 ] {ae453e46-2fb7-4ca9-b578-d8aece1266b9} PushingToViews: Failed to push block to view db_test_o52u1j0s.test_mv_a (e09ce479-ae78-427e-b17c-1e78524c2189), Table is not initialized yet 2025.03.05 21:10:50.153655 [ 23619 ] {ae453e46-2fb7-4ca9-b578-d8aece1266b9} executeQuery: Code: 667. DB::Exception: Table is not initialized yet. (NOT_INITIALIZED) (version 24.3.12.76.altinitystable) (from [::1]:46446) (comment: 02437_drop_mv_restart_replicas.sh) (in query: INSERT INTO db_test_o52u1j0s.test SELECT 'case1', number%3, rand() FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5587: DB::StorageReplicatedMergeTree::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000032497675 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:296: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x0000000030f33887 8. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000033c9c25b 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033c9f541 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 11. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:50.153999 [ 23619 ] {ae453e46-2fb7-4ca9-b578-d8aece1266b9} TCPHandler: Code: 667. DB::Exception: Table is not initialized yet. (NOT_INITIALIZED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5587: DB::StorageReplicatedMergeTree::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000032497675 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:296: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x0000000030f33887 8. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000033c9c25b 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033c9f541 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 11. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:51.091464 [ 23593 ] {c68c8fc3-bde6-4f59-84a1-acf8c3b2e084} PushingToViews: Failed to push block to view db_test_o52u1j0s.test_mv_c (424c6834-9ce2-4ccf-a185-71a17305e44d), Table is not initialized yet 2025.03.05 21:10:51.091642 [ 23593 ] {c68c8fc3-bde6-4f59-84a1-acf8c3b2e084} executeQuery: Code: 667. DB::Exception: Table is not initialized yet. (NOT_INITIALIZED) (version 24.3.12.76.altinitystable) (from [::1]:46776) (comment: 02437_drop_mv_restart_replicas.sh) (in query: INSERT INTO db_test_o52u1j0s.test SELECT 'case1', number%3, rand() FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5587: DB::StorageReplicatedMergeTree::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000032497675 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:296: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x0000000030f33887 8. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000033c9c25b 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033c9f541 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 11. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:51.091861 [ 23593 ] {c68c8fc3-bde6-4f59-84a1-acf8c3b2e084} TCPHandler: Code: 667. DB::Exception: Table is not initialized yet. (NOT_INITIALIZED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5587: DB::StorageReplicatedMergeTree::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000032497675 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:296: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x0000000030f33887 8. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000033c9c25b 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033c9f541 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 11. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:51.129535 [ 14920 ] {bd45d8cc-d21b-4a9f-bf21-149c4c067ecc} executeQuery: Code: 159. DB::Exception: Distributed DDL task /test/test_wmtz716k/rdb/log/query-0000000011 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.312006928 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:36016) (comment: 02445_replicated_db_alter_partition.sh) (in query: delete from rdb_test_wmtz716k.rmt where n=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:51.129722 [ 14920 ] {bd45d8cc-d21b-4a9f-bf21-149c4c067ecc} TCPHandler: Code: 159. DB::Exception: Distributed DDL task /test/test_wmtz716k/rdb/log/query-0000000011 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.312006928 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:51.328095 [ 1340 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_29_29_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:51.332179 [ 1355 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_30_30_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:51.332200 [ 1364 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_31_31_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:51.333018 [ 1364 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_31_31_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:51.641240 [ 1373 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_34_34_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:51.645850 [ 1372 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_35_35_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:51.645963 [ 1369 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_36_36_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:51.646390 [ 1369 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part /var/lib/clickhouse/store/285/2853909d-26f4-499c-afa4-48ab6bb63069/detached/all_28_28_0/ is broken and need manual correction 2025.03.05 21:10:51.646771 [ 1369 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_36_36_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:51.650978 [ 1376 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_38_38_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:51.650978 [ 1362 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_37_37_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:51.651618 [ 1376 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_38_38_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:51.850657 [ 23639 ] {ae26a239-fc3c-47ad-8606-e2c44555ef0b} executeQuery: Code: 81. DB::Exception: Database db_test_o52u1j0s does not exist. Maybe you meant test_o52u1j0s?. (UNKNOWN_DATABASE) (version 24.3.12.76.altinitystable) (from [::1]:46994) (comment: 02437_drop_mv_restart_replicas.sh) (in query: INSERT INTO db_test_o52u1j0s.test SELECT 'case1', number%3, rand() FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a7c0 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f82d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:51.851005 [ 23639 ] {ae26a239-fc3c-47ad-8606-e2c44555ef0b} TCPHandler: Code: 81. DB::Exception: Database db_test_o52u1j0s does not exist. Maybe you meant test_o52u1j0s?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a7c0 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f82d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:51.911593 [ 1373 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_41_41_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:52.611576 [ 22866 ] {1f852254-53e8-4a58-9bbf-95010d62d3bc} InterpreterSystemQuery: SYNC REPLICA test_aubytgly.rmt2 (8311e063-a01b-48d0-8a3e-af008813a93e): Timed out. 2025.03.05 21:10:52.611789 [ 22866 ] {1f852254-53e8-4a58-9bbf-95010d62d3bc} executeQuery: Code: 159. DB::Exception: SYNC REPLICA test_aubytgly.rmt2 (8311e063-a01b-48d0-8a3e-af008813a93e): command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:42498) (comment: 02448_clone_replica_lost_part.sql) (in query: system sync replica rmt2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000031763d7f 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:670: DB::InterpreterSystemQuery::execute() @ 0x000000003174e92b 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:52.611913 [ 22866 ] {1f852254-53e8-4a58-9bbf-95010d62d3bc} TCPHandler: Code: 159. DB::Exception: SYNC REPLICA test_aubytgly.rmt2 (8311e063-a01b-48d0-8a3e-af008813a93e): command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000031763d7f 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:670: DB::InterpreterSystemQuery::execute() @ 0x000000003174e92b 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:52.670490 [ 856 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Will mimic 2 2025.03.05 21:10:52.671799 [ 856 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Source replica does not have part all_10_10_0. Removing it from ZooKeeper. 2025.03.05 21:10:52.671828 [ 856 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Source replica does not have part all_9_9_0. Removing it from ZooKeeper. 2025.03.05 21:10:52.671844 [ 856 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Source replica does not have part all_7_8_1. Removing it from ZooKeeper. 2025.03.05 21:10:52.671858 [ 856 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Source replica does not have part all_11_11_0. Removing it from ZooKeeper. 2025.03.05 21:10:52.845757 [ 1362 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_48_48_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:52.850206 [ 1356 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_49_49_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:52.850393 [ 1371 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_50_50_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:52.850790 [ 1371 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part /var/lib/clickhouse/store/285/2853909d-26f4-499c-afa4-48ab6bb63069/detached/all_41_41_0/ is broken and need manual correction 2025.03.05 21:10:52.851894 [ 1383 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_51_51_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:52.852397 [ 1383 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_51_51_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:52.888225 [ 1371 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: std::exception. Code: 1001, type: std::__1::__fs::filesystem::filesystem_error, e.what() = filesystem error: in file_size: No such file or directory ["/var/lib/clickhouse/store/285/2853909d-26f4-499c-afa4-48ab6bb63069/detached/all_41_41_0/data.cmrk3"], Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./contrib/llvm-project/libcxx/src/support/runtime/stdexcept_default.ipp:33: std::runtime_error::runtime_error(String const&) @ 0x0000000038a4ad9f 2. ./contrib/llvm-project/libcxx/include/string:1499: std::system_error::system_error(std::error_code, String const&) @ 0x0000000038a5375c 3. ./contrib/llvm-project/libcxx/include/__filesystem/filesystem_error.h:42: std::__fs::filesystem::filesystem_error::filesystem_error[abi:v15000](String const&, std::__fs::filesystem::path const&, std::error_code) @ 0x00000000246f132f 4. ./contrib/llvm-project/libcxx/include/__filesystem/filesystem_error.h:90: void std::__fs::filesystem::__throw_filesystem_error[abi:v15000](String&, std::__fs::filesystem::path const&, std::error_code const&) @ 0x00000000389869ac 5. ./contrib/llvm-project/libcxx/src/filesystem/filesystem_common.h:175: std::__fs::filesystem::detail::(anonymous namespace)::ErrorHandler::report(std::error_code const&) const @ 0x000000003898d479 6. ./build_docker/./contrib/llvm-project/libcxx/src/filesystem/operations.cpp:0: std::__fs::filesystem::__file_size(std::__fs::filesystem::path const&, std::error_code*) @ 0x000000003898d340 7. ./build_docker/./src/Disks/DiskLocal.cpp:285: DB::DiskLocal::getFileSize(String const&) const @ 0x000000002f9b2c5e 8. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:90: DB::DataPartStorageOnDiskFull::getFileSize(String const&) const @ 0x000000003297b4af 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartCompact.cpp:0: DB::MergeTreeDataPartCompact::loadIndexGranularityImpl(DB::MergeTreeIndexGranularity&, DB::MergeTreeIndexGranularityInfo const&, unsigned long, DB::IDataPartStorage const&) @ 0x0000000032c39374 10. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:701: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x00000000329d1ef6 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2000: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x00000000323ebc3d 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2063: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323ed365 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 19. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 20. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 Cannot print extra info for Poco::Exception (version 24.3.12.76.altinitystable) 2025.03.05 21:10:52.945184 [ 11389 ] {} DDLWorker(rdb_test_wmtz716k_2): Error on initialization of rdb_test_wmtz716k_2: Code: 57. DB::Exception: Directory for table data store/8cb/8cb9be4f-3d92-4e66-9cf9-a4887ed01d67/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cef63 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002f79b712 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002f790b23 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002f7c06e8 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002f7bcc21 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1141: DB::DDLWorker::runMainThread() @ 0x000000002fd4bf30 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:53.126968 [ 11405 ] {} DDLWorker(rdb_test_wmtz716k_3): Error on initialization of rdb_test_wmtz716k_3: Code: 57. DB::Exception: Directory for table data store/8cb/8cb9be4f-3d92-4e66-9cf9-a4887ed01d67/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cef63 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002f79b712 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002f790b23 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002f7c06e8 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002f7bcc21 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1141: DB::DDLWorker::runMainThread() @ 0x000000002fd4bf30 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:53.887670 [ 1376 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_60_60_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:53.895045 [ 1374 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_61_61_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:53.895104 [ 1369 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_63_63_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:53.895826 [ 1369 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_63_63_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:53.900366 [ 1376 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_65_65_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:53.900369 [ 1361 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_66_66_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:53.900373 [ 1370 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_64_64_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:53.901012 [ 1376 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_65_65_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:53.901043 [ 1361 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part /var/lib/clickhouse/store/285/2853909d-26f4-499c-afa4-48ab6bb63069/detached/all_55_55_0/ is broken and need manual correction 2025.03.05 21:10:53.901291 [ 1361 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_66_66_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:53.901528 [ 1361 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part /var/lib/clickhouse/store/285/2853909d-26f4-499c-afa4-48ab6bb63069/detached/all_53_53_0/ is broken and need manual correction 2025.03.05 21:10:53.908724 [ 1369 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_67_67_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:53.908795 [ 1357 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_68_68_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:53.909341 [ 1357 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_68_68_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:53.909341 [ 1369 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_67_67_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:53.909884 [ 1357 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_68_68_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:53.913400 [ 1370 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_69_69_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:53.913877 [ 1370 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_69_69_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:53.938566 [ 1361 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: std::exception. Code: 1001, type: std::__1::__fs::filesystem::filesystem_error, e.what() = filesystem error: in file_size: No such file or directory ["/var/lib/clickhouse/store/285/2853909d-26f4-499c-afa4-48ab6bb63069/detached/all_53_53_0/count.txt"], Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./contrib/llvm-project/libcxx/src/support/runtime/stdexcept_default.ipp:33: std::runtime_error::runtime_error(String const&) @ 0x0000000038a4ad9f 2. ./contrib/llvm-project/libcxx/include/string:1499: std::system_error::system_error(std::error_code, String const&) @ 0x0000000038a5375c 3. ./contrib/llvm-project/libcxx/include/__filesystem/filesystem_error.h:42: std::__fs::filesystem::filesystem_error::filesystem_error[abi:v15000](String const&, std::__fs::filesystem::path const&, std::error_code) @ 0x00000000246f132f 4. ./contrib/llvm-project/libcxx/include/__filesystem/filesystem_error.h:90: void std::__fs::filesystem::__throw_filesystem_error[abi:v15000](String&, std::__fs::filesystem::path const&, std::error_code const&) @ 0x00000000389869ac 5. ./contrib/llvm-project/libcxx/src/filesystem/filesystem_common.h:175: std::__fs::filesystem::detail::(anonymous namespace)::ErrorHandler::report(std::error_code const&) const @ 0x000000003898d479 6. ./build_docker/./contrib/llvm-project/libcxx/src/filesystem/operations.cpp:0: std::__fs::filesystem::__file_size(std::__fs::filesystem::path const&, std::error_code*) @ 0x000000003898d340 7. ./build_docker/./src/Disks/DiskLocal.cpp:285: DB::DiskLocal::getFileSize(String const&) const @ 0x000000002f9b2c5e 8. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:90: DB::DataPartStorageOnDiskFull::getFileSize(String const&) const @ 0x000000003297b4af 9. ./build_docker/./src/Storages/MergeTree/PartMetadataManagerOrdinary.cpp:13: DB::PartMetadataManagerOrdinary::read(String const&) const @ 0x0000000032f1447f 10. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:1291: DB::IMergeTreeDataPart::loadRowsCount()::$_0::operator()() const @ 0x00000000329e7c38 11. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:0: DB::IMergeTreeDataPart::loadRowsCount() @ 0x00000000329d8132 12. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:706: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x00000000329d2152 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2000: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x00000000323ebc3d 14. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2063: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323ed365 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 21. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 22. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 23. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 Cannot print extra info for Poco::Exception (version 24.3.12.76.altinitystable) 2025.03.05 21:10:53.946183 [ 23586 ] {c6430be6-229d-4945-8f9e-2c45fb8e2f6a} executeQuery: Code: 81. DB::Exception: Database db_test_o52u1j0s does not exist. Maybe you meant test_o52u1j0s?. (UNKNOWN_DATABASE) (version 24.3.12.76.altinitystable) (from [::1]:47798) (comment: 02437_drop_mv_restart_replicas.sh) (in query: INSERT INTO db_test_o52u1j0s.test SELECT 'case1', number%3, rand() FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a7c0 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f82d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:53.946484 [ 23586 ] {c6430be6-229d-4945-8f9e-2c45fb8e2f6a} TCPHandler: Code: 81. DB::Exception: Database db_test_o52u1j0s does not exist. Maybe you meant test_o52u1j0s?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a7c0 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f82d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:54.458342 [ 1356 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_73_73_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:54.463584 [ 1372 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_74_74_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:54.463647 [ 1383 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_75_75_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:54.464619 [ 1374 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_76_76_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:54.465145 [ 1383 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_75_75_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:54.465288 [ 1374 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_76_76_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:54.470067 [ 1370 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_77_77_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:54.649397 [ 23612 ] {38c62748-b502-4fbb-8101-7eb778cc2434} executeQuery: Code: 159. DB::Exception: Distributed DDL task /test/test_wmtz716k/rdb/log/query-0000000012 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.320006945 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:46842) (comment: 02445_replicated_db_alter_partition.sh) (in query: alter table rdb_test_wmtz716k.mt update n=2 where n=3), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:54.649680 [ 23612 ] {38c62748-b502-4fbb-8101-7eb778cc2434} TCPHandler: Code: 159. DB::Exception: Distributed DDL task /test/test_wmtz716k/rdb/log/query-0000000012 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.320006945 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:55.090750 [ 1356 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_82_82_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:55.093920 [ 1372 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_83_83_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:55.093946 [ 1362 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_84_84_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:55.094635 [ 1362 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_84_84_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:55.602462 [ 1340 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_88_88_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:55.606486 [ 1363 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_89_89_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:55.607363 [ 1356 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_90_90_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:55.608224 [ 1356 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_90_90_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:55.612158 [ 1364 ] {} test_ldjp8y9n.alter_table1 (2853909d-26f4-499c-afa4-48ab6bb63069): Part all_91_91_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:56.070327 [ 1357 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_94_94_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:56.074432 [ 1357 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_95_95_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:56.075055 [ 1356 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_96_96_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:56.079823 [ 1371 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_98_98_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:56.079903 [ 1340 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_97_97_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:56.080456 [ 1371 ] {} test_ldjp8y9n.alter_table0 (f292e1b7-bb08-4f40-92bc-07dbf6db1378): Part all_98_98_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.03.05 21:10:56.515439 [ 23587 ] {8699b157-431e-470c-8a93-fb22ef0ad4fa} executeQuery: Code: 81. DB::Exception: Database db_test_o52u1j0s does not exist. Maybe you meant test_o52u1j0s?. (UNKNOWN_DATABASE) (version 24.3.12.76.altinitystable) (from [::1]:48340) (comment: 02437_drop_mv_restart_replicas.sh) (in query: INSERT INTO db_test_o52u1j0s.test SELECT 'case1', number%3, rand() FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a7c0 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f82d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:56.515703 [ 23587 ] {8699b157-431e-470c-8a93-fb22ef0ad4fa} TCPHandler: Code: 81. DB::Exception: Database db_test_o52u1j0s does not exist. Maybe you meant test_o52u1j0s?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a7c0 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f82d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:57.093748 [ 6346 ] {02435_insert_test_pk1gbwzd_12019-19875-2} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:57.285776 [ 23587 ] {02435_insert_test_pk1gbwzd_12019-19875-2} executeQuery: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:42362) (comment: 02435_rollback_cancelled_queries.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:57.286502 [ 23587 ] {02435_insert_test_pk1gbwzd_12019-19875-2} DynamicQueryHandler: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:57.300730 [ 23587 ] {02435_insert_test_pk1gbwzd_12019-19875-2} DynamicQueryHandler: Cannot send exception to client: Code: 27. DB::Exception: Cannot parse input: expected '\r\n' at end of stream. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dbfd7 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:57.314274 [ 23587 ] {02435_insert_test_pk1gbwzd_12019-19875-2} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:42362). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:57.314530 [ 23587 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:57.948595 [ 11389 ] {} DDLWorker(rdb_test_wmtz716k_2): Error on initialization of rdb_test_wmtz716k_2: Code: 57. DB::Exception: Directory for table data store/8cb/8cb9be4f-3d92-4e66-9cf9-a4887ed01d67/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cef63 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002f79b712 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002f790b23 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002f7c06e8 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002f7bcc21 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1141: DB::DDLWorker::runMainThread() @ 0x000000002fd4bf30 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:58.131153 [ 11405 ] {} DDLWorker(rdb_test_wmtz716k_3): Error on initialization of rdb_test_wmtz716k_3: Code: 57. DB::Exception: Directory for table data store/8cb/8cb9be4f-3d92-4e66-9cf9-a4887ed01d67/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cef63 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002f79b712 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002f790b23 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002f7c06e8 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002f7bcc21 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1141: DB::DDLWorker::runMainThread() @ 0x000000002fd4bf30 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:58.395091 [ 23593 ] {dead1c32-86af-4dab-8ba1-b8ecad2d7a58} executeQuery: Code: 159. DB::Exception: Distributed DDL task /test/test_wmtz716k/rdb/log/query-0000000013 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.324006954 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:47974) (comment: 02445_replicated_db_alter_partition.sh) (in query: alter table rdb_test_wmtz716k.rmt update n=2 where n=3), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:58.395417 [ 23593 ] {dead1c32-86af-4dab-8ba1-b8ecad2d7a58} TCPHandler: Code: 159. DB::Exception: Distributed DDL task /test/test_wmtz716k/rdb/log/query-0000000013 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.324006954 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:58.579104 [ 730 ] {86b0a879-7af2-4154-8df2-d41889d65983} PushingToViews: Failed to push block to view db_test_o52u1j0s.test_mv_b (be7fc19e-7ff9-4368-99fe-bc4936ffd30f), Table db_test_o52u1j0s..inner_id.be7fc19e-7ff9-4368-99fe-bc4936ffd30f is dropped or detached 2025.03.05 21:10:58.604057 [ 730 ] {86b0a879-7af2-4154-8df2-d41889d65983} executeQuery: Code: 218. DB::Exception: Table db_test_o52u1j0s..inner_id.be7fc19e-7ff9-4368-99fe-bc4936ffd30f is dropped or detached. (TABLE_IS_DROPPED) (version 24.3.12.76.altinitystable) (from [::1]:48694) (comment: 02437_drop_mv_restart_replicas.sh) (in query: INSERT INTO db_test_o52u1j0s.test SELECT 'case1', number%3, rand() FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Storages/IStorage.cpp:64: DB::IStorage::lockForShare(String const&, std::chrono::duration> const&) @ 0x00000000320dd146 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033c9ef7a 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:296: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x0000000030f33887 8. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000033c9c25b 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033c9f541 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 11. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:58.606557 [ 730 ] {86b0a879-7af2-4154-8df2-d41889d65983} TCPHandler: Code: 218. DB::Exception: Table db_test_o52u1j0s..inner_id.be7fc19e-7ff9-4368-99fe-bc4936ffd30f is dropped or detached. (TABLE_IS_DROPPED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Storages/IStorage.cpp:64: DB::IStorage::lockForShare(String const&, std::chrono::duration> const&) @ 0x00000000320dd146 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033c9ef7a 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:296: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x0000000030f33887 8. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000033c9c25b 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033c9f541 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 11. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:10:58.709922 [ 23642 ] {02435_insert_test_pk1gbwzd_11307-12706-4} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:42378). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:58.710235 [ 23642 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:58.825145 [ 23610 ] {02435_insert_test_pk1gbwzd_22438-6192-5} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:42392). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:58.825409 [ 23610 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:59.264376 [ 23621 ] {} DynamicQueryHandler: Code: 373. DB::Exception: Session 02435_session_test_pk1gbwzd_23425.23023.11 is locked by a concurrent client. (SESSION_IS_LOCKED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/Session.cpp:133: DB::NamedSessionsStorage::acquireSession(std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&, String const&, std::chrono::duration>, bool) @ 0x000000003133cba9 5. ./build_docker/./src/Interpreters/Session.cpp:0: DB::Session::makeSessionContext(String const&, std::chrono::duration>, bool) @ 0x00000000313384a2 6. ./build_docker/./src/Server/HTTPHandler.cpp:568: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333cf02c 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:59.605709 [ 11370 ] {02434_insert_test_dkfhjyr0_3717-9857-2} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:59.653723 [ 23612 ] {02435_insert_test_pk1gbwzd_20884-14560-8} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:42440). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:10:59.653958 [ 23612 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:00.109463 [ 765 ] {} test_aubytgly.rmt2 (ReplicatedMergeTreeCleanupThread): Will mark replica 1 as lost, because it has stale log pointer: log-0000000026 2025.03.05 21:11:00.386789 [ 5753 ] {02434_insert_test_dkfhjyr0_3717-9857-2} executeQuery: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:51500) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:00.388023 [ 5753 ] {02434_insert_test_dkfhjyr0_3717-9857-2} DynamicQueryHandler: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:00.388216 [ 5753 ] {02434_insert_test_dkfhjyr0_3717-9857-2} DynamicQueryHandler: Cannot send exception to client: Code: 27. DB::Exception: Cannot parse input: expected '\r\n' at end of stream. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dbfd7 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:00.388565 [ 5753 ] {02434_insert_test_dkfhjyr0_3717-9857-2} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51500). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:00.388968 [ 5753 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:00.477693 [ 730 ] {02435_insert_test_pk1gbwzd_32402-26122-10} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:42442). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:00.477894 [ 730 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:00.809057 [ 23620 ] {02435_insert_test_pk1gbwzd_16304-30776-13} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33002). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:33002) (comment: 02435_rollback_cancelled_queries.sh) (in query: insert into dedup_test settings max_insert_block_size=110000, min_insert_block_size_rows=110000 format TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::readDataNext() @ 0x00000000334a89b2 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0813 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:00.859051 [ 23620 ] {02435_insert_test_pk1gbwzd_16304-30776-13} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33002). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:00.859141 [ 23620 ] {02435_insert_test_pk1gbwzd_16304-30776-13} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33002). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::readDataNext() @ 0x00000000334a89b2 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0813 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:00.859357 [ 23620 ] {02435_insert_test_pk1gbwzd_16304-30776-13} TCPHandler: Client has gone away. 2025.03.05 21:11:01.490240 [ 1025 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Will mimic 2 2025.03.05 21:11:01.491992 [ 1025 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Source replica does not have part all_15_15_0. Removing it from ZooKeeper. 2025.03.05 21:11:01.492006 [ 1025 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Source replica does not have part all_10_10_0_13. Removing it from ZooKeeper. 2025.03.05 21:11:01.492015 [ 1025 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Source replica does not have part all_12_12_0_13. Removing it from ZooKeeper. 2025.03.05 21:11:01.492025 [ 1025 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Source replica does not have part all_14_14_0. Removing it from ZooKeeper. 2025.03.05 21:11:01.492034 [ 1025 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Source replica does not have part all_16_16_0. Removing it from ZooKeeper. 2025.03.05 21:11:01.492043 [ 1025 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Source replica does not have part all_11_11_0_13. Removing it from ZooKeeper. 2025.03.05 21:11:01.492053 [ 1025 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Source replica does not have part all_18_18_0. Removing it from ZooKeeper. 2025.03.05 21:11:01.492063 [ 1025 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Source replica does not have part all_17_17_0. Removing it from ZooKeeper. 2025.03.05 21:11:01.492071 [ 1025 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Source replica does not have part all_19_19_0. Removing it from ZooKeeper. 2025.03.05 21:11:01.492080 [ 1025 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Source replica does not have part all_7_8_1_13. Removing it from ZooKeeper. 2025.03.05 21:11:01.492090 [ 1025 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Source replica does not have part all_9_9_0_13. Removing it from ZooKeeper. 2025.03.05 21:11:01.494134 [ 1025 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Source replica does not have part all_18_18_0. Removing it from working set. 2025.03.05 21:11:01.494156 [ 1025 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): Source replica does not have part all_19_19_0. Removing it from working set. 2025.03.05 21:11:01.507699 [ 1371 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_23_23_0&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_23_23_0&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_23_23_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:11:01.507717 [ 1372 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_18_22_1&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_18_22_1&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_18_22_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:11:01.507933 [ 1372 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_18_22_1&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:01.507940 [ 1371 ] {} test_aubytgly.rmt1 (ec73cab9-c4f6-4d84-9b5c-bb9b224a64ae): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F02448%2Ftest_aubytgly%2Frmt%2Freplicas%2F2&part=all_23_23_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:01.513501 [ 23562 ] {02435_insert_test_pk1gbwzd_5406-10233-11} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51516). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:01.513713 [ 23562 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:01.550962 [ 22865 ] {} DynamicQueryHandler: Code: 373. DB::Exception: Session 02435_session_test_pk1gbwzd_21821.21199.16 is locked by a concurrent client. (SESSION_IS_LOCKED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/Session.cpp:133: DB::NamedSessionsStorage::acquireSession(std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&, String const&, std::chrono::duration>, bool) @ 0x000000003133cba9 5. ./build_docker/./src/Interpreters/Session.cpp:0: DB::Session::makeSessionContext(String const&, std::chrono::duration>, bool) @ 0x00000000313384a2 6. ./build_docker/./src/Server/HTTPHandler.cpp:568: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333cf02c 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:02.084343 [ 6311 ] {02434_insert_test_dkfhjyr0_5221-14109-4} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 33. DB::Exception: Unexpected EOF, got 26607616 of 38888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:02.345672 [ 778 ] {} test_yqp33qkp.rmt2 (8affe5fa-90b9-441d-bee3-8001b238414c): Metadata version (2) on replica is not up to date with metadata (1) on source replica 1 2025.03.05 21:11:02.375050 [ 1375 ] {} test_yqp33qkp.rmt2 (8affe5fa-90b9-441d-bee3-8001b238414c): Attempt to update metadata of version 2 to older version 1 when processing log entry queue-0000000000: format version: 4 create_time: 2025-03-05 21:11:02 source replica: 1 block_id: alter alter_version 1 have_mutation 0 columns_str_size: 69 columns format version: 1 3 columns: `n` Int32 `m` Int32 `k` UInt128 metadata_str_size: 226 metadata format version: 1 date column: sampling expression: index granularity: 49622 mode: 0 sign column: primary key: data format version: 1 partition key: granularity bytes: 25219135 merge parameters format version: 2 2025.03.05 21:11:02.482830 [ 23611 ] {3ccc7892-2ae8-4143-b5b9-7c583f145fe6} executeQuery: Code: 36. DB::Exception: From array size and to array size mismatch: In scope SELECT bitmapTransform(arrayReduce('groupBitmapState', [1]), [1, 2], [1, 2, 3]). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:33278) (comment: 02430_bitmap_transform_exception_code.sql) (in query: SELECT bitmapTransform(arrayReduce('groupBitmapState', [1]), [1, 2], [1, 2, 3]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::FunctionBitmapTransform::executeIntType(std::vector> const&, unsigned long) const @ 0x0000000018149cbd 5. DB::FunctionBitmapTransform::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000181472be 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:11:02.482845 [ 3522 ] {2e4ace3a-64e0-48b6-97f0-db347e42b8ab} executeQuery: Code: 81. DB::Exception: Database db_test_o52u1j0s does not exist. Maybe you meant test_o52u1j0s?. (UNKNOWN_DATABASE) (version 24.3.12.76.altinitystable) (from [::1]:33270) (comment: 02437_drop_mv_restart_replicas.sh) (in query: INSERT INTO db_test_o52u1j0s.test SELECT 'case1', number%3, rand() FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a7c0 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f82d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:02.483433 [ 3522 ] {2e4ace3a-64e0-48b6-97f0-db347e42b8ab} TCPHandler: Code: 81. DB::Exception: Database db_test_o52u1j0s does not exist. Maybe you meant test_o52u1j0s?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a7c0 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f82d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:02.496874 [ 23611 ] {3ccc7892-2ae8-4143-b5b9-7c583f145fe6} TCPHandler: Code: 36. DB::Exception: From array size and to array size mismatch: In scope SELECT bitmapTransform(arrayReduce('groupBitmapState', [1]), [1, 2], [1, 2, 3]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::FunctionBitmapTransform::executeIntType(std::vector> const&, unsigned long) const @ 0x0000000018149cbd 5. DB::FunctionBitmapTransform::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000181472be 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:11:02.689450 [ 23590 ] {} DynamicQueryHandler: Code: 373. DB::Exception: Session 02435_session_test_pk1gbwzd_22630.8857.19 is locked by a concurrent client. (SESSION_IS_LOCKED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/Session.cpp:133: DB::NamedSessionsStorage::acquireSession(std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&, String const&, std::chrono::duration>, bool) @ 0x000000003133cba9 5. ./build_docker/./src/Interpreters/Session.cpp:0: DB::Session::makeSessionContext(String const&, std::chrono::duration>, bool) @ 0x00000000313384a2 6. ./build_docker/./src/Server/HTTPHandler.cpp:568: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333cf02c 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:02.701934 [ 22863 ] {02434_insert_test_dkfhjyr0_5221-14109-4} executeQuery: Code: 33. DB::Exception: Unexpected EOF, got 26607616 of 38888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:51554) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:02.703153 [ 22863 ] {02434_insert_test_dkfhjyr0_5221-14109-4} DynamicQueryHandler: Code: 33. DB::Exception: Unexpected EOF, got 26607616 of 38888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:02.716629 [ 22863 ] {02434_insert_test_dkfhjyr0_5221-14109-4} DynamicQueryHandler: Cannot send exception to client: Code: 33. DB::Exception: Unexpected EOF, got 26738688 of 38888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:02.719022 [ 22863 ] {02434_insert_test_dkfhjyr0_5221-14109-4} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51554). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:02.719261 [ 22863 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:02.899494 [ 23611 ] {f5c01366-0750-4709-937a-fafa208f609b} executeQuery: Code: 60. DB::Exception: Table db_test_o52u1j0s.test does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33354) (comment: 02437_drop_mv_restart_replicas.sh) (in query: INSERT INTO db_test_o52u1j0s.test SELECT 'case1', number%3, rand() FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:02.899771 [ 23611 ] {f5c01366-0750-4709-937a-fafa208f609b} TCPHandler: Code: 60. DB::Exception: Table db_test_o52u1j0s.test does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:02.952109 [ 11389 ] {} DDLWorker(rdb_test_wmtz716k_2): Error on initialization of rdb_test_wmtz716k_2: Code: 57. DB::Exception: Directory for table data store/8cb/8cb9be4f-3d92-4e66-9cf9-a4887ed01d67/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cef63 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002f79b712 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002f790b23 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002f7c06e8 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002f7bcc21 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1141: DB::DDLWorker::runMainThread() @ 0x000000002fd4bf30 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:03.519641 [ 23582 ] {2d22fd23-18fc-4bae-9d00-1d4b855c2467} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000015 */ ALTER TABLE rdb_test_wmtz716k.mt DROP PARTITION ID 'all', ADD COLUMN `m` int), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 11. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:03.521000 [ 23582 ] {2d22fd23-18fc-4bae-9d00-1d4b855c2467} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:33492) (comment: 02445_replicated_db_alter_partition.sh) (in query: alter table rdb_test_wmtz716k.mt drop partition id 'all', add column m int), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 11. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:03.521395 [ 23582 ] {2d22fd23-18fc-4bae-9d00-1d4b855c2467} TCPHandler: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 11. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:03.574409 [ 730 ] {134d8364-b300-4ff2-b127-1769970d9892} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(min, UInt8) of argument for aggregate function groupBitmapAnd. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:33450) (comment: 02429_groupBitmap_chain_state.sql) (in query: SELECT groupBitmapAnd(z) FROM ( SELECT minState(u) AS z FROM ( SELECT 123 AS u ) AS a1 ) AS a2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionBitmapL2(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002866ff08 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:03.574690 [ 730 ] {134d8364-b300-4ff2-b127-1769970d9892} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(min, UInt8) of argument for aggregate function groupBitmapAnd. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionBitmapL2(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002866ff08 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:03.600618 [ 730 ] {3a761da3-b1e0-4342-b2ec-2033534f373a} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(max, String) of argument for aggregate function groupBitmapOr. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:33450) (comment: 02429_groupBitmap_chain_state.sql) (in query: SELECT groupBitmapOr(z) FROM ( SELECT maxState(u) AS z FROM ( SELECT '123' AS u ) AS a1 ) AS a2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionBitmapL2(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000028670c68 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:03.600667 [ 23620 ] {02435_insert_test_pk1gbwzd_15204-4886-15} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51570). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:03.600934 [ 730 ] {3a761da3-b1e0-4342-b2ec-2033534f373a} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(max, String) of argument for aggregate function groupBitmapOr. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionBitmapL2(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000028670c68 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:03.600997 [ 23620 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:03.649495 [ 730 ] {4c3a261f-6c4a-4b41-bf6c-e281e5f2a7d4} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(count) of argument for aggregate function groupBitmapXor. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:33450) (comment: 02429_groupBitmap_chain_state.sql) (in query: SELECT groupBitmapXor(z) FROM ( SELECT countState() AS z FROM ( SELECT '123' AS u ) AS a1 ) AS a2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionBitmapL2(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000286719c8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:03.649730 [ 730 ] {4c3a261f-6c4a-4b41-bf6c-e281e5f2a7d4} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(count) of argument for aggregate function groupBitmapXor. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionBitmapL2(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000286719c8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:03.658482 [ 23597 ] {9e080095-154d-4008-8277-9b206202b468} PushingToViews: Trying to access table test_92eejde5.test_race_condition_mv_3 but it doesn't exist 2025.03.05 21:11:03.814901 [ 23619 ] {4d7b0d35-5b1e-48b4-af8b-f9d8b981ca2e} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000016 */ ALTER TABLE rdb_test_wmtz716k.rmt DROP PARTITION ID 'all', ADD COLUMN `m` int), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:847: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002fd66c40 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:656: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5e951 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:03.816337 [ 23619 ] {4d7b0d35-5b1e-48b4-af8b-f9d8b981ca2e} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:33630) (comment: 02445_replicated_db_alter_partition.sh) (in query: alter table rdb_test_wmtz716k.rmt drop partition id 'all', add column m int), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:847: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002fd66c40 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:656: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5e951 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:03.816808 [ 23619 ] {4d7b0d35-5b1e-48b4-af8b-f9d8b981ca2e} TCPHandler: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:847: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002fd66c40 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:656: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5e951 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:04.181198 [ 22865 ] {02435_insert_test_pk1gbwzd_16561-20321-19} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51622). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:04.181559 [ 22865 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:04.251505 [ 10241 ] {ec107d00-f1aa-4a74-9768-2718a24020d1} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000017 */ ALTER TABLE rdb_test_wmtz716k.mt DROP PARTITION ID 'all', UPDATE n = 2 WHERE 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 11. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:04.252446 [ 10241 ] {ec107d00-f1aa-4a74-9768-2718a24020d1} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:33700) (comment: 02445_replicated_db_alter_partition.sh) (in query: alter table rdb_test_wmtz716k.mt drop partition id 'all', update n = 2 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 11. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:04.252755 [ 10241 ] {ec107d00-f1aa-4a74-9768-2718a24020d1} TCPHandler: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 11. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030793c7b 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:04.567652 [ 10241 ] {5a958d2a-56db-4c9e-a4cf-47e6f17627ea} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:33732) (comment: 02445_replicated_db_alter_partition.sh) (in query: alter table rdb_test_wmtz716k.rmt drop partition id 'all', update n = 2 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:04.568119 [ 10241 ] {5a958d2a-56db-4c9e-a4cf-47e6f17627ea} TCPHandler: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:190: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030796bb3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:05.153614 [ 6258 ] {02434_insert_test_dkfhjyr0_12274-27801-7} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 33. DB::Exception: Unexpected EOF, got 26673152 of 38888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:06.074482 [ 14920 ] {02434_insert_test_dkfhjyr0_12274-27801-7} executeQuery: Code: 33. DB::Exception: Unexpected EOF, got 26673152 of 38888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:51656) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:06.081463 [ 14920 ] {02434_insert_test_dkfhjyr0_12274-27801-7} DynamicQueryHandler: Code: 33. DB::Exception: Unexpected EOF, got 26673152 of 38888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:06.081607 [ 14920 ] {02434_insert_test_dkfhjyr0_12274-27801-7} DynamicQueryHandler: Cannot send exception to client: Code: 33. DB::Exception: Unexpected EOF, got 26869760 of 38888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:06.081842 [ 14920 ] {02434_insert_test_dkfhjyr0_12274-27801-7} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51656). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:06.082213 [ 14920 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:07.136989 [ 1883 ] {02434_insert_test_dkfhjyr0_20484-3413-8} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:07.533703 [ 22859 ] {02435_insert_test_pk1gbwzd_22302-26787-16} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51606). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:07.533912 [ 22859 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:07.618109 [ 11456 ] {02434_insert_test_dkfhjyr0_18469-19517-9} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:07.860103 [ 23611 ] {dde69286-8814-42b9-bca0-71762335923d} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(257)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:33914) (comment: 02426_create_suspicious_fixed_string.sql) (in query: CREATE TABLE suspicious_fixed_string (`id` UInt64, `s` FixedString(257)) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 32076, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.1686999499797821, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 136195391, compact_parts_max_granules_to_buffer = 238, compact_parts_merge_max_bytes_to_prefetch_part = 16182328, merge_max_block_size = 9065, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 37, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 6946410, concurrent_part_removal_threshold = 64, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 10572, primary_key_compress_block_size = 97370), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:109: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000031773180 6. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:07.860302 [ 23611 ] {dde69286-8814-42b9-bca0-71762335923d} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(257)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x00000000317762b2 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:0: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x000000003177512c 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:109: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000031773180 6. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000307bb5a3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5de6 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:07.926156 [ 10241 ] {02434_insert_test_dkfhjyr0_20484-3413-8} executeQuery: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:51694) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:07.933642 [ 10241 ] {02434_insert_test_dkfhjyr0_20484-3413-8} DynamicQueryHandler: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:07.933827 [ 10241 ] {02434_insert_test_dkfhjyr0_20484-3413-8} DynamicQueryHandler: Cannot send exception to client: Code: 27. DB::Exception: Cannot parse input: expected '\r\n' at end of stream. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dbfd7 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:07.934153 [ 10241 ] {02434_insert_test_dkfhjyr0_20484-3413-8} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51694). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:07.934471 [ 10241 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:07.955753 [ 11389 ] {} DDLWorker(rdb_test_wmtz716k_2): Error on initialization of rdb_test_wmtz716k_2: Code: 57. DB::Exception: Directory for table data store/8cb/8cb9be4f-3d92-4e66-9cf9-a4887ed01d67/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cef63 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002f79b712 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002f790b23 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002f7c06e8 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002f7bcc21 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1141: DB::DDLWorker::runMainThread() @ 0x000000002fd4bf30 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:08.311628 [ 12524 ] {02434_insert_test_dkfhjyr0_29903-30356-10} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:33900). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:33900) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_dist settings max_insert_block_size=110000, min_insert_block_size_rows=110000 format TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::readDataNext() @ 0x00000000334a89b2 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0813 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:08.312206 [ 12524 ] {02434_insert_test_dkfhjyr0_29903-30356-10} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33900). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:08.312267 [ 12524 ] {02434_insert_test_dkfhjyr0_29903-30356-10} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:33900). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::readDataNext() @ 0x00000000334a89b2 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0813 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:08.312414 [ 12524 ] {02434_insert_test_dkfhjyr0_29903-30356-10} TCPHandler: Client has gone away. 2025.03.05 21:11:08.322076 [ 3522 ] {02435_insert_test_pk1gbwzd_5564-13790-30} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33890). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:33890) (comment: 02435_rollback_cancelled_queries.sh) (in query: insert into dedup_test settings max_insert_block_size=110000, min_insert_block_size_rows=110000 format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::readDataNext() @ 0x00000000334a89b2 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0813 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:08.323010 [ 3522 ] {02435_insert_test_pk1gbwzd_5564-13790-30} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33890). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:08.323074 [ 3522 ] {02435_insert_test_pk1gbwzd_5564-13790-30} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33890). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::readDataNext() @ 0x00000000334a89b2 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0813 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:08.323219 [ 3522 ] {02435_insert_test_pk1gbwzd_5564-13790-30} TCPHandler: Client has gone away. 2025.03.05 21:11:08.339912 [ 23622 ] {9833d875-99d9-4566-a218-a2e6130ca5db} executeQuery: Code: 159. DB::Exception: Distributed DDL task /test/test_wmtz716k/rdb/log/query-0000000018 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.316006936 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:33766) (comment: 02445_replicated_db_alter_partition.sh) (in query: alter table rdb_test_wmtz716k.mt update n=2 where n=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:08.340206 [ 23622 ] {9833d875-99d9-4566-a218-a2e6130ca5db} TCPHandler: Code: 159. DB::Exception: Distributed DDL task /test/test_wmtz716k/rdb/log/query-0000000018 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.316006936 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:08.427661 [ 23606 ] {02434_insert_test_dkfhjyr0_18469-19517-9} executeQuery: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:51730) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:08.428832 [ 23606 ] {02434_insert_test_dkfhjyr0_18469-19517-9} DynamicQueryHandler: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:08.429004 [ 23606 ] {02434_insert_test_dkfhjyr0_18469-19517-9} DynamicQueryHandler: Cannot send exception to client: Code: 27. DB::Exception: Cannot parse input: expected '\r\n' at end of stream. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dbfd7 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:08.429263 [ 23606 ] {02434_insert_test_dkfhjyr0_18469-19517-9} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51730). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:08.429518 [ 23606 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:08.500623 [ 23597 ] {9e080095-154d-4008-8277-9b206202b468} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33560). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:33560) (comment: 02479_race_condition_between_insert_and_droppin_mv.sh) (in query: INSERT INTO test_race_condition_landing SELECT number, toString(number), toString(number) from system.numbers limit 36468, 500 settings ignore_materialized_views_with_dropped_target_table=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::TCPHandler::runImpl() @ 0x0000000033487bf2 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:08.501095 [ 23597 ] {9e080095-154d-4008-8277-9b206202b468} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33560). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:08.501139 [ 23597 ] {9e080095-154d-4008-8277-9b206202b468} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33560). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::TCPHandler::runImpl() @ 0x0000000033487bf2 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:08.501255 [ 23597 ] {9e080095-154d-4008-8277-9b206202b468} TCPHandler: Client has gone away. 2025.03.05 21:11:08.749734 [ 5753 ] {73bc4f62-2d4f-4ce3-9294-8c4762335cb7} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33534). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:33534) (comment: 02479_race_condition_between_insert_and_droppin_mv.sh) (in query: INSERT INTO test_race_condition_landing SELECT number, toString(number), toString(number) from system.numbers limit 45707, 500 settings ignore_materialized_views_with_dropped_target_table=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::TCPHandler::runImpl() @ 0x0000000033487bf2 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:08.750034 [ 5753 ] {73bc4f62-2d4f-4ce3-9294-8c4762335cb7} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33534). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:08.750074 [ 5753 ] {73bc4f62-2d4f-4ce3-9294-8c4762335cb7} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33534). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::TCPHandler::runImpl() @ 0x0000000033487bf2 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:08.750182 [ 5753 ] {73bc4f62-2d4f-4ce3-9294-8c4762335cb7} TCPHandler: Client has gone away. 2025.03.05 21:11:08.918007 [ 23611 ] {} DynamicQueryHandler: Code: 373. DB::Exception: Session 02435_session_test_pk1gbwzd_7177.9281.33 is locked by a concurrent client. (SESSION_IS_LOCKED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/Session.cpp:133: DB::NamedSessionsStorage::acquireSession(std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&, String const&, std::chrono::duration>, bool) @ 0x000000003133cba9 5. ./build_docker/./src/Interpreters/Session.cpp:0: DB::Session::makeSessionContext(String const&, std::chrono::duration>, bool) @ 0x00000000313384a2 6. ./build_docker/./src/Server/HTTPHandler.cpp:568: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333cf02c 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:08.943593 [ 22858 ] {02435_insert_test_pk1gbwzd_30159-14757-26} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51698). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:08.943810 [ 22858 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:09.127413 [ 22865 ] {28dbc075-f1aa-41a0-ba17-c317596c56f1} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:56492) (comment: 02425_categorical_information_value_properties.sql) (in query: SELECT categoricalInformationValue(c1, c2) FROM VALUES((NULL, 1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:0: DB::(anonymous namespace)::createAggregateFunctionCategoricalIV(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000289e8f24 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d5de0 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:09.127661 [ 22865 ] {28dbc075-f1aa-41a0-ba17-c317596c56f1} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:0: DB::(anonymous namespace)::createAggregateFunctionCategoricalIV(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000289e8f24 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d5de0 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:09.203441 [ 22865 ] {077f23de-a6da-4fee-8530-8116d0091157} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:56492) (comment: 02425_categorical_information_value_properties.sql) (in query: SELECT categoricalInformationValue(c1, c2) FROM VALUES((NULL, NULL));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:0: DB::(anonymous namespace)::createAggregateFunctionCategoricalIV(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000289e8f24 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d5de0 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:09.203606 [ 22865 ] {077f23de-a6da-4fee-8530-8116d0091157} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:0: DB::(anonymous namespace)::createAggregateFunctionCategoricalIV(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000289e8f24 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d5de0 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:09.267631 [ 23582 ] {da14348c-66d1-4042-80f6-00df899fe9b8} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33548). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:33548) (comment: 02479_race_condition_between_insert_and_droppin_mv.sh) (in query: INSERT INTO test_race_condition_landing SELECT number, toString(number), toString(number) from system.numbers limit 53842, 500 settings ignore_materialized_views_with_dropped_target_table=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::TCPHandler::runImpl() @ 0x0000000033487bf2 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:09.267974 [ 23582 ] {da14348c-66d1-4042-80f6-00df899fe9b8} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33548). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:09.268016 [ 23582 ] {da14348c-66d1-4042-80f6-00df899fe9b8} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33548). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::TCPHandler::runImpl() @ 0x0000000033487bf2 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:09.268132 [ 23582 ] {da14348c-66d1-4042-80f6-00df899fe9b8} TCPHandler: Client has gone away. 2025.03.05 21:11:09.485262 [ 23620 ] {} DynamicQueryHandler: Code: 373. DB::Exception: Session 02435_session_test_pk1gbwzd_6538.2890.35 is locked by a concurrent client. (SESSION_IS_LOCKED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/Session.cpp:133: DB::NamedSessionsStorage::acquireSession(std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&, String const&, std::chrono::duration>, bool) @ 0x000000003133cba9 5. ./build_docker/./src/Interpreters/Session.cpp:0: DB::Session::makeSessionContext(String const&, std::chrono::duration>, bool) @ 0x00000000313384a2 6. ./build_docker/./src/Server/HTTPHandler.cpp:568: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333cf02c 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:09.666743 [ 23586 ] {02435_insert_test_pk1gbwzd_26734-28772-29} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51724). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:09.666957 [ 23586 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:09.882649 [ 1851 ] {02434_insert_test_dkfhjyr0_12857-7613-11} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 33. DB::Exception: Unexpected EOF, got 28573696 of 38888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:10.382080 [ 10241 ] {0c9388d6-96ad-4e90-81cb-887f72494889} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(UInt8))): In scope SELECT formatRow('RawBLOB', [[[33]], []]). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:56584) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', [[[33]], []]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x00000000319452e1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:21: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000033aa1115 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000033582528 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b948add 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:10.382400 [ 10241 ] {0c9388d6-96ad-4e90-81cb-887f72494889} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(UInt8))): In scope SELECT formatRow('RawBLOB', [[[33]], []]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x00000000319452e1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:21: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000033aa1115 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000033582528 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b948add 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:10.401088 [ 10241 ] {679bd948-f9f9-4787-8ff1-d82d2c220559} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Nothing))): In scope SELECT formatRow('RawBLOB', [[[]], []]). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:56584) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', [[[]], []]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x00000000319452e1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:21: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000033aa1115 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000033582528 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b948add 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:10.401282 [ 10241 ] {679bd948-f9f9-4787-8ff1-d82d2c220559} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Nothing))): In scope SELECT formatRow('RawBLOB', [[[]], []]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x00000000319452e1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:21: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000033aa1115 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000033582528 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b948add 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:10.404302 [ 10241 ] {95a73e39-7568-4b9e-8a2d-670aca3d7e8f} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Array(Array(Array(Array(UInt8))))))): In scope SELECT formatRow('RawBLOB', [[[[[[[72, 101, 108, 108, 111]]]]]], []]). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:56584) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', [[[[[[[0x48, 0x65, 0x6c, 0x6c, 0x6f]]]]]], []]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x00000000319452e1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:21: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000033aa1115 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000033582528 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b948add 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:10.404459 [ 10241 ] {95a73e39-7568-4b9e-8a2d-670aca3d7e8f} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Array(Array(Array(Array(UInt8))))))): In scope SELECT formatRow('RawBLOB', [[[[[[[72, 101, 108, 108, 111]]]]]], []]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x00000000319452e1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:21: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000033aa1115 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000033582528 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b948add 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:10.406500 [ 10241 ] {814273e6-c0d3-400e-ac90-f39408cc4431} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Nothing)): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(Array(Nothing))')). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:56584) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', []::Array(Array(Nothing)));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x00000000319452e1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:21: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000033aa1115 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000033582528 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b948add 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:10.406621 [ 10241 ] {814273e6-c0d3-400e-ac90-f39408cc4431} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Nothing)): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(Array(Nothing))')). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x00000000319452e1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:21: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000033aa1115 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000033582528 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b948add 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:10.408756 [ 10241 ] {79324c78-c500-4631-8da7-6c7041445d68} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[], [['Hello']]]). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:56584) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', [[], [['Hello']]]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x00000000319452e1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:21: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000033aa1115 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000033582528 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b948add 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:10.408893 [ 10241 ] {79324c78-c500-4631-8da7-6c7041445d68} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[], [['Hello']]]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x00000000319452e1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:21: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000033aa1115 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000033582528 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b948add 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:10.419257 [ 10241 ] {ad4e8082-4824-47f7-bb85-0607a7d56371} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[['World']], []]). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:56584) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', [[['World']], []]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x00000000319452e1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:21: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000033aa1115 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000033582528 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b948add 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:10.419397 [ 10241 ] {ad4e8082-4824-47f7-bb85-0607a7d56371} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[['World']], []]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x00000000319452e1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:21: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000033aa1115 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000033582528 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b948add 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:10.421326 [ 10241 ] {4b827ef1-3175-41d9-861b-56a06b4ebf16} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(String): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(String)')). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:56584) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', []::Array(String));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x00000000319452e1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:21: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000033aa1115 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000033582528 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b948add 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:10.421458 [ 10241 ] {4b827ef1-3175-41d9-861b-56a06b4ebf16} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(String): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(String)')). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x00000000319452e1 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:21: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000033aa1115 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:73: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x0000000033582528 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b948add 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:10.430648 [ 3522 ] {02434_insert_test_dkfhjyr0_12857-7613-11} executeQuery: Code: 33. DB::Exception: Unexpected EOF, got 28573696 of 38888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:51752) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:10.435697 [ 3522 ] {02434_insert_test_dkfhjyr0_12857-7613-11} DynamicQueryHandler: Code: 33. DB::Exception: Unexpected EOF, got 28573696 of 38888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:10.435883 [ 3522 ] {02434_insert_test_dkfhjyr0_12857-7613-11} DynamicQueryHandler: Cannot send exception to client: Code: 33. DB::Exception: Unexpected EOF, got 28639232 of 38888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:10.436144 [ 3522 ] {02434_insert_test_dkfhjyr0_12857-7613-11} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51752). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:10.436406 [ 3522 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:11.072902 [ 23619 ] {02435_insert_test_pk1gbwzd_26791-14052-38} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:56592). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:56592) (comment: 02435_rollback_cancelled_queries.sh) (in query: insert into dedup_test settings max_insert_block_size=110000, min_insert_block_size_rows=110000 format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::readDataNext() @ 0x00000000334a89b2 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0813 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:11.073677 [ 23619 ] {02435_insert_test_pk1gbwzd_26791-14052-38} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56592). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:11.073715 [ 23619 ] {02435_insert_test_pk1gbwzd_26791-14052-38} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:56592). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::readDataNext() @ 0x00000000334a89b2 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0813 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:11.073837 [ 23619 ] {02435_insert_test_pk1gbwzd_26791-14052-38} TCPHandler: Client has gone away. 2025.03.05 21:11:11.158329 [ 23590 ] {02435_insert_test_pk1gbwzd_14133-18060-22} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51652). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:11.158619 [ 23590 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:11.936022 [ 23601 ] {2b47a0ef-da76-4c13-b945-c4490081ee00} executeQuery: Code: 36. DB::Exception: Unknown explain kind ''. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:56636) (comment: 02421_explain_subquery.sql) (in query: SELECT * FROM viewExplain('', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./src/Parsers/ASTExplainQuery.h:66: DB::ASTExplainQuery::fromString(String const&) @ 0x000000002e4fa44a 5. ./build_docker/./src/TableFunctions/TableFunctionExplain.cpp:85: DB::(anonymous namespace)::TableFunctionExplain::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4f6ddc 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002e8efbe7 7. ./build_docker/./src/Interpreters/Context.cpp:1844: DB::Context::executeTableFunction(std::shared_ptr const&, DB::ASTSelectQuery const*) @ 0x000000002fc555ed 8. ./build_docker/./src/Interpreters/JoinedTables.cpp:212: DB::JoinedTables::getLeftTableStorage() @ 0x00000000310fdec9 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f4e994 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:11.949500 [ 23601 ] {2b47a0ef-da76-4c13-b945-c4490081ee00} TCPHandler: Code: 36. DB::Exception: Unknown explain kind ''. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./src/Parsers/ASTExplainQuery.h:66: DB::ASTExplainQuery::fromString(String const&) @ 0x000000002e4fa44a 5. ./build_docker/./src/TableFunctions/TableFunctionExplain.cpp:85: DB::(anonymous namespace)::TableFunctionExplain::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4f6ddc 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002e8efbe7 7. ./build_docker/./src/Interpreters/Context.cpp:1844: DB::Context::executeTableFunction(std::shared_ptr const&, DB::ASTSelectQuery const*) @ 0x000000002fc555ed 8. ./build_docker/./src/Interpreters/JoinedTables.cpp:212: DB::JoinedTables::getLeftTableStorage() @ 0x00000000310fdec9 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f4e994 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:11.985971 [ 23601 ] {099567b5-932e-456e-8149-dd86d1da1f7f} executeQuery: Code: 36. DB::Exception: Table function 'viewExplain' requires a query argument. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:56636) (comment: 02421_explain_subquery.sql) (in query: SELECT * FROM viewExplain('EXPLAIN AST', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/TableFunctions/TableFunctionExplain.cpp:0: DB::(anonymous namespace)::TableFunctionExplain::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4f7d6d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002e8efbe7 6. ./build_docker/./src/Interpreters/Context.cpp:1844: DB::Context::executeTableFunction(std::shared_ptr const&, DB::ASTSelectQuery const*) @ 0x000000002fc555ed 7. ./build_docker/./src/Interpreters/JoinedTables.cpp:212: DB::JoinedTables::getLeftTableStorage() @ 0x00000000310fdec9 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f4e994 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:11.986189 [ 23601 ] {099567b5-932e-456e-8149-dd86d1da1f7f} TCPHandler: Code: 36. DB::Exception: Table function 'viewExplain' requires a query argument. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/TableFunctions/TableFunctionExplain.cpp:0: DB::(anonymous namespace)::TableFunctionExplain::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4f7d6d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002e8efbe7 6. ./build_docker/./src/Interpreters/Context.cpp:1844: DB::Context::executeTableFunction(std::shared_ptr const&, DB::ASTSelectQuery const*) @ 0x000000002fc555ed 7. ./build_docker/./src/Interpreters/JoinedTables.cpp:212: DB::JoinedTables::getLeftTableStorage() @ 0x00000000310fdec9 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f4e994 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:12.018295 [ 23601 ] {70b887ce-48dc-43bd-be73-ab5e2707ec56} executeQuery: Code: 36. DB::Exception: Table function 'viewExplain' requires a subquery argument, got '1'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:56636) (comment: 02421_explain_subquery.sql) (in query: SELECT * FROM viewExplain('EXPLAIN AST', '', 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/TableFunctions/TableFunctionExplain.cpp:0: DB::(anonymous namespace)::TableFunctionExplain::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4f8028 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002e8efbe7 6. ./build_docker/./src/Interpreters/Context.cpp:1844: DB::Context::executeTableFunction(std::shared_ptr const&, DB::ASTSelectQuery const*) @ 0x000000002fc555ed 7. ./build_docker/./src/Interpreters/JoinedTables.cpp:212: DB::JoinedTables::getLeftTableStorage() @ 0x00000000310fdec9 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f4e994 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:12.018552 [ 23601 ] {70b887ce-48dc-43bd-be73-ab5e2707ec56} TCPHandler: Code: 36. DB::Exception: Table function 'viewExplain' requires a subquery argument, got '1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/TableFunctions/TableFunctionExplain.cpp:0: DB::(anonymous namespace)::TableFunctionExplain::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4f8028 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002e8efbe7 6. ./build_docker/./src/Interpreters/Context.cpp:1844: DB::Context::executeTableFunction(std::shared_ptr const&, DB::ASTSelectQuery const*) @ 0x000000002fc555ed 7. ./build_docker/./src/Interpreters/JoinedTables.cpp:212: DB::JoinedTables::getLeftTableStorage() @ 0x00000000310fdec9 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f4e994 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:12.050046 [ 23601 ] {acfd03c1-2673-4103-95d2-36ac486620d6} executeQuery: Code: 36. DB::Exception: Table function 'viewExplain' requires a subquery argument, got ''''. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:56636) (comment: 02421_explain_subquery.sql) (in query: SELECT * FROM viewExplain('EXPLAIN AST', '', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/TableFunctions/TableFunctionExplain.cpp:0: DB::(anonymous namespace)::TableFunctionExplain::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4f8028 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002e8efbe7 6. ./build_docker/./src/Interpreters/Context.cpp:1844: DB::Context::executeTableFunction(std::shared_ptr const&, DB::ASTSelectQuery const*) @ 0x000000002fc555ed 7. ./build_docker/./src/Interpreters/JoinedTables.cpp:212: DB::JoinedTables::getLeftTableStorage() @ 0x00000000310fdec9 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f4e994 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:12.050243 [ 23601 ] {acfd03c1-2673-4103-95d2-36ac486620d6} TCPHandler: Code: 36. DB::Exception: Table function 'viewExplain' requires a subquery argument, got ''''. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/TableFunctions/TableFunctionExplain.cpp:0: DB::(anonymous namespace)::TableFunctionExplain::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4f8028 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002e8efbe7 6. ./build_docker/./src/Interpreters/Context.cpp:1844: DB::Context::executeTableFunction(std::shared_ptr const&, DB::ASTSelectQuery const*) @ 0x000000002fc555ed 7. ./build_docker/./src/Interpreters/JoinedTables.cpp:212: DB::JoinedTables::getLeftTableStorage() @ 0x00000000310fdec9 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f4e994 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:12.197338 [ 11364 ] {02434_insert_test_dkfhjyr0_23949-2939-14} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 33. DB::Exception: Unexpected EOF, got 9764864 of 38888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:12.216900 [ 5848 ] {02434_insert_test_dkfhjyr0_3603-27425-13} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:12.543261 [ 14920 ] {02435_insert_test_pk1gbwzd_15757-15982-35} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:50662). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:12.543492 [ 14920 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:12.732104 [ 23611 ] {0ac8cd60-fc99-4eb6-be14-892edf7547bc} executeQuery: Code: 159. DB::Exception: Distributed DDL task /test/test_wmtz716k/rdb/log/query-0000000019 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.316006936 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:56506) (comment: 02445_replicated_db_alter_partition.sh) (in query: delete from rdb_test_wmtz716k.mt where n=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:12.732470 [ 23611 ] {0ac8cd60-fc99-4eb6-be14-892edf7547bc} TCPHandler: Code: 159. DB::Exception: Distributed DDL task /test/test_wmtz716k/rdb/log/query-0000000019 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.316006936 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:12.751646 [ 23601 ] {586e8931-e280-4d29-b651-4aa300436cf3} executeQuery: Code: 36. DB::Exception: Unknown explain kind ''. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:56636) (comment: 02421_explain_subquery.sql) (in query: SELECT * FROM viewExplain('', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./src/Parsers/ASTExplainQuery.h:66: DB::ASTExplainQuery::fromString(String const&) @ 0x000000002e4fa44a 5. ./build_docker/./src/TableFunctions/TableFunctionExplain.cpp:85: DB::(anonymous namespace)::TableFunctionExplain::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4f6ddc 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:12.751872 [ 23601 ] {586e8931-e280-4d29-b651-4aa300436cf3} TCPHandler: Code: 36. DB::Exception: Unknown explain kind ''. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./src/Parsers/ASTExplainQuery.h:66: DB::ASTExplainQuery::fromString(String const&) @ 0x000000002e4fa44a 5. ./build_docker/./src/TableFunctions/TableFunctionExplain.cpp:85: DB::(anonymous namespace)::TableFunctionExplain::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4f6ddc 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:12.805298 [ 23601 ] {3479b67e-451f-45af-b3cd-d4d68f95879d} executeQuery: Code: 36. DB::Exception: Table function 'viewExplain' requires a query argument. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:56636) (comment: 02421_explain_subquery.sql) (in query: SELECT * FROM viewExplain('EXPLAIN AST', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/TableFunctions/TableFunctionExplain.cpp:0: DB::(anonymous namespace)::TableFunctionExplain::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4f7d6d 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:12.805589 [ 23601 ] {3479b67e-451f-45af-b3cd-d4d68f95879d} TCPHandler: Code: 36. DB::Exception: Table function 'viewExplain' requires a query argument. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/TableFunctions/TableFunctionExplain.cpp:0: DB::(anonymous namespace)::TableFunctionExplain::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4f7d6d 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:12.849734 [ 23601 ] {ee1490a6-e394-4d17-8152-1c52f6607de4} executeQuery: Code: 36. DB::Exception: Table function 'viewExplain' requires a subquery argument, got '1'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:56636) (comment: 02421_explain_subquery.sql) (in query: SELECT * FROM viewExplain('EXPLAIN AST', '', 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/TableFunctions/TableFunctionExplain.cpp:0: DB::(anonymous namespace)::TableFunctionExplain::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4f8028 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:12.849818 [ 23562 ] {02435_insert_test_pk1gbwzd_3195-21438-23} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51670). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:12.849967 [ 23601 ] {ee1490a6-e394-4d17-8152-1c52f6607de4} TCPHandler: Code: 36. DB::Exception: Table function 'viewExplain' requires a subquery argument, got '1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/TableFunctions/TableFunctionExplain.cpp:0: DB::(anonymous namespace)::TableFunctionExplain::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4f8028 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:12.850138 [ 23562 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:12.862880 [ 23601 ] {f1376fca-603d-4fff-9014-43be7073a2a2} executeQuery: Code: 36. DB::Exception: Table function 'viewExplain' requires a subquery argument, got ''''. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:56636) (comment: 02421_explain_subquery.sql) (in query: SELECT * FROM viewExplain('EXPLAIN AST', '', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/TableFunctions/TableFunctionExplain.cpp:0: DB::(anonymous namespace)::TableFunctionExplain::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4f8028 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:12.863087 [ 23601 ] {f1376fca-603d-4fff-9014-43be7073a2a2} TCPHandler: Code: 36. DB::Exception: Table function 'viewExplain' requires a subquery argument, got ''''. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/TableFunctions/TableFunctionExplain.cpp:0: DB::(anonymous namespace)::TableFunctionExplain::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4f8028 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:12.940253 [ 23620 ] {02434_insert_test_dkfhjyr0_3603-27425-13} executeQuery: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50748) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:12.941336 [ 23620 ] {02434_insert_test_dkfhjyr0_3603-27425-13} DynamicQueryHandler: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:12.941513 [ 23620 ] {02434_insert_test_dkfhjyr0_3603-27425-13} DynamicQueryHandler: Cannot send exception to client: Code: 27. DB::Exception: Cannot parse input: expected '\r\n' at end of stream. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dbfd7 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:12.941815 [ 23620 ] {02434_insert_test_dkfhjyr0_3603-27425-13} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:50748). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:12.942051 [ 23620 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:12.960038 [ 11389 ] {} DDLWorker(rdb_test_wmtz716k_2): Error on initialization of rdb_test_wmtz716k_2: Code: 57. DB::Exception: Directory for table data store/8cb/8cb9be4f-3d92-4e66-9cf9-a4887ed01d67/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cef63 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002f79b712 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002f790b23 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002f7c06e8 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002f7bcc21 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1141: DB::DDLWorker::runMainThread() @ 0x000000002fd4bf30 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:13.012579 [ 22866 ] {02435_insert_test_pk1gbwzd_28578-16460-25} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51692). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:13.018097 [ 22866 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:13.018193 [ 23622 ] {02434_insert_test_dkfhjyr0_23949-2939-14} executeQuery: Code: 33. DB::Exception: Unexpected EOF, got 9764864 of 38888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50770) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:13.019258 [ 23622 ] {02434_insert_test_dkfhjyr0_23949-2939-14} DynamicQueryHandler: Code: 33. DB::Exception: Unexpected EOF, got 9764864 of 38888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:13.019452 [ 23622 ] {02434_insert_test_dkfhjyr0_23949-2939-14} DynamicQueryHandler: Cannot send exception to client: Code: 33. DB::Exception: Unexpected EOF, got 9830400 of 38888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:13.019727 [ 23622 ] {02434_insert_test_dkfhjyr0_23949-2939-14} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:50770). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:13.019982 [ 23622 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:13.089986 [ 11437 ] {02435_insert_test_pk1gbwzd_348-16499-42} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 33. DB::Exception: Unexpected EOF, got 4456448 of 6888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:13.275009 [ 1658 ] {02435_insert_test_pk1gbwzd_9038-26033-27} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51706). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:13.275256 [ 1658 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:13.648754 [ 5753 ] {02435_insert_test_pk1gbwzd_348-16499-42} executeQuery: Code: 33. DB::Exception: Unexpected EOF, got 4456448 of 6888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50788) (comment: 02435_rollback_cancelled_queries.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:13.649600 [ 5753 ] {02435_insert_test_pk1gbwzd_348-16499-42} DynamicQueryHandler: Code: 33. DB::Exception: Unexpected EOF, got 4456448 of 6888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:13.649741 [ 5753 ] {02435_insert_test_pk1gbwzd_348-16499-42} DynamicQueryHandler: Cannot send exception to client: Code: 33. DB::Exception: Unexpected EOF, got 5505024 of 6888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:13.649972 [ 5753 ] {02435_insert_test_pk1gbwzd_348-16499-42} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:50788). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:13.650172 [ 5753 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:13.679420 [ 22863 ] {02435_insert_test_pk1gbwzd_15272-10709-28} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51708). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:13.679762 [ 22863 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:13.744538 [ 1902 ] {02434_insert_test_dkfhjyr0_28614-27466-16} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:14.097742 [ 23612 ] {} DynamicQueryHandler: Code: 373. DB::Exception: Session 02435_session_test_pk1gbwzd_13619.6849.46 is locked by a concurrent client. (SESSION_IS_LOCKED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/Session.cpp:133: DB::NamedSessionsStorage::acquireSession(std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&, String const&, std::chrono::duration>, bool) @ 0x000000003133cba9 5. ./build_docker/./src/Interpreters/Session.cpp:0: DB::Session::makeSessionContext(String const&, std::chrono::duration>, bool) @ 0x00000000313384a2 6. ./build_docker/./src/Server/HTTPHandler.cpp:568: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333cf02c 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:14.912610 [ 3522 ] {02434_insert_test_dkfhjyr0_28614-27466-16} executeQuery: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50818) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:14.920188 [ 3522 ] {02434_insert_test_dkfhjyr0_28614-27466-16} DynamicQueryHandler: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:14.920440 [ 3522 ] {02434_insert_test_dkfhjyr0_28614-27466-16} DynamicQueryHandler: Cannot send exception to client: Code: 27. DB::Exception: Cannot parse input: expected '\r\n' at end of stream. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dbfd7 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:14.920704 [ 3522 ] {02434_insert_test_dkfhjyr0_28614-27466-16} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:50818). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:14.920921 [ 3522 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:15.026840 [ 6264 ] {02435_insert_test_pk1gbwzd_20215-26740-48} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 33. DB::Exception: Unexpected EOF, got 6684672 of 6888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:472: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9f34 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:15.372972 [ 23612 ] {02434_insert_test_dkfhjyr0_16228-7745-18} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:56850). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:56850) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test settings max_insert_block_size=110000, min_insert_block_size_rows=110000 format TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::readDataNext() @ 0x00000000334a89b2 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0813 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:15.373719 [ 23612 ] {02434_insert_test_dkfhjyr0_16228-7745-18} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56850). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:15.373768 [ 23612 ] {02434_insert_test_dkfhjyr0_16228-7745-18} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:56850). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::readDataNext() @ 0x00000000334a89b2 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0813 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:15.373889 [ 23612 ] {02434_insert_test_dkfhjyr0_16228-7745-18} TCPHandler: Client has gone away. 2025.03.05 21:11:15.535639 [ 1844 ] {02434_insert_test_dkfhjyr0_5748-14709-17} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:15.780925 [ 23606 ] {02435_insert_test_pk1gbwzd_94-25117-33} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51800). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:15.781124 [ 23606 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:15.804961 [ 6278 ] {02435_insert_test_pk1gbwzd_16394-1807-50} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:15.904030 [ 23582 ] {02435_insert_test_pk1gbwzd_20215-26740-48} executeQuery: Code: 33. DB::Exception: Unexpected EOF, got 6684672 of 6888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50894) (comment: 02435_rollback_cancelled_queries.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:472: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9f34 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:15.904556 [ 23582 ] {02435_insert_test_pk1gbwzd_20215-26740-48} DynamicQueryHandler: Code: 33. DB::Exception: Unexpected EOF, got 6684672 of 6888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:472: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9f34 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:15.917814 [ 23582 ] {02435_insert_test_pk1gbwzd_20215-26740-48} DynamicQueryHandler: Cannot send exception to client: Code: 33. DB::Exception: Unexpected data, got 7405621 bytes, expected 6888890. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:0: DB::LimitReadBuffer::nextImpl() @ 0x00000000249923ce 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:15.918144 [ 23582 ] {02435_insert_test_pk1gbwzd_20215-26740-48} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:50894). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:15.918363 [ 23582 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:15.944451 [ 11331 ] {02434_insert_test_dkfhjyr0_21760-30747-19} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 33. DB::Exception: Unexpected EOF, got 9699328 of 38888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:15.949261 [ 14920 ] {02435_insert_test_pk1gbwzd_24278-27516-51} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:56902). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:56902) (comment: 02435_rollback_cancelled_queries.sh) (in query: insert into dedup_test settings max_insert_block_size=110000, min_insert_block_size_rows=110000 format TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::readDataNext() @ 0x00000000334a89b2 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0813 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:15.950114 [ 14920 ] {02435_insert_test_pk1gbwzd_24278-27516-51} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56902). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:15.950165 [ 14920 ] {02435_insert_test_pk1gbwzd_24278-27516-51} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:56902). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::readDataNext() @ 0x00000000334a89b2 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0813 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:15.950310 [ 14920 ] {02435_insert_test_pk1gbwzd_24278-27516-51} TCPHandler: Client has gone away. 2025.03.05 21:11:16.084489 [ 23597 ] {02434_insert_test_dkfhjyr0_5748-14709-17} executeQuery: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50834) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:16.097575 [ 23597 ] {02434_insert_test_dkfhjyr0_5748-14709-17} DynamicQueryHandler: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:16.097750 [ 23597 ] {02434_insert_test_dkfhjyr0_5748-14709-17} DynamicQueryHandler: Cannot send exception to client: Code: 27. DB::Exception: Cannot parse input: expected '\r\n' at end of stream. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dbfd7 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:16.098008 [ 23597 ] {02434_insert_test_dkfhjyr0_5748-14709-17} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:50834). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:16.098217 [ 23597 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:16.510752 [ 1843 ] {02434_insert_test_dkfhjyr0_23762-31522-20} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 33. DB::Exception: Unexpected EOF, got 9764864 of 38888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:16.781019 [ 23611 ] {02435_insert_test_pk1gbwzd_16394-1807-50} executeQuery: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50930) (comment: 02435_rollback_cancelled_queries.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:16.784983 [ 23611 ] {02435_insert_test_pk1gbwzd_16394-1807-50} DynamicQueryHandler: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:16.785139 [ 23611 ] {02435_insert_test_pk1gbwzd_16394-1807-50} DynamicQueryHandler: Cannot send exception to client: Code: 27. DB::Exception: Cannot parse input: expected '\r\n' at end of stream. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dbfd7 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:16.785405 [ 23611 ] {02435_insert_test_pk1gbwzd_16394-1807-50} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:50930). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:16.785643 [ 23611 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:16.851333 [ 12525 ] {02434_insert_test_dkfhjyr0_21760-30747-19} executeQuery: Code: 33. DB::Exception: Unexpected EOF, got 9699328 of 38888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50938) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:16.857420 [ 12525 ] {02434_insert_test_dkfhjyr0_21760-30747-19} DynamicQueryHandler: Code: 33. DB::Exception: Unexpected EOF, got 9699328 of 38888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:16.857586 [ 12525 ] {02434_insert_test_dkfhjyr0_21760-30747-19} DynamicQueryHandler: Cannot send exception to client: Code: 33. DB::Exception: Unexpected EOF, got 10747904 of 38888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:16.857837 [ 12525 ] {02434_insert_test_dkfhjyr0_21760-30747-19} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:50938). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:16.858062 [ 12525 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:16.973935 [ 23586 ] {7daf72fe-6537-4511-b941-b0c84365db76} executeQuery: Code: 159. DB::Exception: Distributed DDL task /test/test_wmtz716k/rdb/log/query-0000000020 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.30800692 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:56772) (comment: 02445_replicated_db_alter_partition.sh) (in query: delete from rdb_test_wmtz716k.mt where n=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:16.974221 [ 23586 ] {7daf72fe-6537-4511-b941-b0c84365db76} TCPHandler: Code: 159. DB::Exception: Distributed DDL task /test/test_wmtz716k/rdb/log/query-0000000020 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.30800692 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:17.075688 [ 14920 ] {02434_insert_test_dkfhjyr0_19049-24862-21} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:56964). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:56964) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test settings max_insert_block_size=110000, min_insert_block_size_rows=110000 format TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::readDataNext() @ 0x00000000334a89b2 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0813 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:17.076425 [ 14920 ] {02434_insert_test_dkfhjyr0_19049-24862-21} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56964). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:17.076473 [ 14920 ] {02434_insert_test_dkfhjyr0_19049-24862-21} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:56964). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::readDataNext() @ 0x00000000334a89b2 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0813 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:17.076591 [ 14920 ] {02434_insert_test_dkfhjyr0_19049-24862-21} TCPHandler: Client has gone away. 2025.03.05 21:11:17.149006 [ 23620 ] {02434_insert_test_dkfhjyr0_23762-31522-20} executeQuery: Code: 33. DB::Exception: Unexpected EOF, got 9764864 of 38888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50984) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:17.149927 [ 23620 ] {02434_insert_test_dkfhjyr0_23762-31522-20} DynamicQueryHandler: Code: 33. DB::Exception: Unexpected EOF, got 9764864 of 38888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:17.150079 [ 23620 ] {02434_insert_test_dkfhjyr0_23762-31522-20} DynamicQueryHandler: Cannot send exception to client: Code: 33. DB::Exception: Unexpected EOF, got 9830400 of 38888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:17.150353 [ 23620 ] {02434_insert_test_dkfhjyr0_23762-31522-20} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:50984). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:17.150612 [ 23620 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:17.280673 [ 23628 ] {02434_insert_test_dkfhjyr0_25592-29981-0} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:42332). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:17.280972 [ 23628 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:18.295312 [ 22859 ] {02435_insert_test_pk1gbwzd_6342-5977-43} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:50802). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:18.295534 [ 22859 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:18.366859 [ 10241 ] {02435_insert_test_pk1gbwzd_20501-15061-39} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:50766). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:18.367074 [ 10241 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:18.498921 [ 23635 ] {02434_insert_test_dkfhjyr0_12855-30777-1} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:42406). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:18.499164 [ 23635 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:18.575935 [ 23619 ] {f30c5e8b-1baf-40f2-8cca-35db5ee94c32} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Nullable(UInt8)): While executing AggregatingTransform. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:57164) (comment: 02419_contingency_array_nullable.sql) (in query: SELECT contingency(1, [1, NULL]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x00000000319452e1 5. ./src/AggregateFunctions/UniqVariadicHash.h:50: DB::UniqVariadicHash::apply(unsigned long, DB::IColumn const**, unsigned long) @ 0x0000000027697c7b 6. ./src/AggregateFunctions/IAggregateFunction.h:697: DB::AggregateFunctionCrossTab::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x00000000286651f2 7. ./src/AggregateFunctions/IAggregateFunction.h:536: DB::IAggregateFunctionHelper>::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000028667003 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1406: DB::Aggregator::addBatchSinglePlace(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char*, DB::Arena*) @ 0x000000002fe5e502 9. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x000000002fe5f185 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1611: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe64045 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 16. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 17. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 18. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:18.576354 [ 23619 ] {f30c5e8b-1baf-40f2-8cca-35db5ee94c32} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Nullable(UInt8)): While executing AggregatingTransform. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Columns/ColumnArray.cpp:0: DB::ColumnArray::getDataAt(unsigned long) const @ 0x00000000319452e1 5. ./src/AggregateFunctions/UniqVariadicHash.h:50: DB::UniqVariadicHash::apply(unsigned long, DB::IColumn const**, unsigned long) @ 0x0000000027697c7b 6. ./src/AggregateFunctions/IAggregateFunction.h:697: DB::AggregateFunctionCrossTab::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x00000000286651f2 7. ./src/AggregateFunctions/IAggregateFunction.h:536: DB::IAggregateFunctionHelper>::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000028667003 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1406: DB::Aggregator::addBatchSinglePlace(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char*, DB::Arena*) @ 0x000000002fe5e502 9. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x000000002fe5f185 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1611: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe64045 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 16. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 17. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 18. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:18.767365 [ 730 ] {02435_insert_test_pk1gbwzd_3104-142-46} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:50850). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:18.767626 [ 730 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:18.802120 [ 22865 ] {02435_insert_test_pk1gbwzd_3821-14720-44} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:50826). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:18.802353 [ 22865 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:19.260517 [ 23577 ] {02434_insert_test_dkfhjyr0_5250-19677-3} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51540). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:19.260766 [ 23577 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:19.504245 [ 23573 ] {02434_insert_test_dkfhjyr0_14467-7984-5} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51582). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:19.504483 [ 23573 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:20.418382 [ 6353 ] {02434_insert_test_dkfhjyr0_16529-5842-26} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:472: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9f34 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:20.776358 [ 23590 ] {02434_insert_test_dkfhjyr0_16529-5842-26} executeQuery: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:42190) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:472: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9f34 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:20.793274 [ 23590 ] {02434_insert_test_dkfhjyr0_16529-5842-26} DynamicQueryHandler: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:472: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9f34 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:20.793439 [ 23590 ] {02434_insert_test_dkfhjyr0_16529-5842-26} DynamicQueryHandler: Cannot send exception to client: Code: 27. DB::Exception: Cannot parse input: expected '\r\n' at end of stream. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dbfd7 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:20.793657 [ 23590 ] {02434_insert_test_dkfhjyr0_16529-5842-26} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:42190). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:20.793863 [ 23590 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:21.872598 [ 11384 ] {02434_insert_test_dkfhjyr0_15388-29455-27} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:21.932232 [ 14973 ] {febd8674-9765-4c97-931d-28401f426a5b} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'a' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.3.12.76.altinitystable). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.3.12.76.altinitystable) (from [::1]:43618) (comment: 02416_json_object_inference.sql) (in query: desc format(JSONEachRow, '{"a" : {"b" : {"c" : 1, "d" : "str"}}}');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:480: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033518072 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4f121d 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:21.932373 [ 14973 ] {febd8674-9765-4c97-931d-28401f426a5b} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'a' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.3.12.76.altinitystable). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:480: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033518072 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4f121d 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:22.168059 [ 22860 ] {02434_insert_test_dkfhjyr0_15388-29455-27} executeQuery: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:42198) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:22.169063 [ 22860 ] {02434_insert_test_dkfhjyr0_15388-29455-27} DynamicQueryHandler: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:22.169221 [ 22860 ] {02434_insert_test_dkfhjyr0_15388-29455-27} DynamicQueryHandler: Cannot send exception to client: Code: 27. DB::Exception: Cannot parse input: expected '\r\n' at end of stream. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dbfd7 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:22.169478 [ 22860 ] {02434_insert_test_dkfhjyr0_15388-29455-27} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:42198). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:22.169701 [ 22860 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:22.203040 [ 11223 ] {02434_insert_test_dkfhjyr0_7707-14627-28} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:22.569207 [ 23610 ] {02434_insert_test_dkfhjyr0_7707-14627-28} executeQuery: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:42244) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:22.570115 [ 23610 ] {02434_insert_test_dkfhjyr0_7707-14627-28} DynamicQueryHandler: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:22.570273 [ 23610 ] {02434_insert_test_dkfhjyr0_7707-14627-28} DynamicQueryHandler: Cannot send exception to client: Code: 27. DB::Exception: Cannot parse input: expected '\r\n' at end of stream. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dbfd7 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:22.570529 [ 23610 ] {02434_insert_test_dkfhjyr0_7707-14627-28} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:42244). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:22.570755 [ 23610 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:22.641190 [ 23610 ] {95f58923-3a1e-48d1-ae6e-09268f629d0b} executeQuery: Poco::Exception. Code: 1000, e.code() = 0, Exception: Unsupported language for region name. Supported languages are: 'ru', 'en', 'ua', 'uk', 'by', 'kz', 'tr', 'de', 'uz', 'lv', 'lt', 'et', 'pt', 'he', 'vi', 'es'. (version 24.3.12.76.altinitystable) (from [::1]:43684) (comment: 02411_legacy_geobase.sql) (in query: SELECT regionToName(number::UInt32, 'xy') FROM numbers(13);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:32: Poco::Exception::Exception(String&&, int) @ 0x000000003697a9a5 2. DB::RegionsNames::getLanguageEnum(String const&) @ 0x000000001880507d 3. DB::FunctionRegionToName::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018803ab5 4. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 5. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 6. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 11. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 13. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:22.641469 [ 23610 ] {95f58923-3a1e-48d1-ae6e-09268f629d0b} TCPHandler: Code: 1000. DB::Exception: Exception: Unsupported language for region name. Supported languages are: 'ru', 'en', 'ua', 'uk', 'by', 'kz', 'tr', 'de', 'uz', 'lv', 'lt', 'et', 'pt', 'he', 'vi', 'es'. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:32: Poco::Exception::Exception(String&&, int) @ 0x000000003697a9a5 2. DB::RegionsNames::getLanguageEnum(String const&) @ 0x000000001880507d 3. DB::FunctionRegionToName::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018803ab5 4. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 5. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 6. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 11. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 13. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:25.080448 [ 11468 ] {02434_insert_test_dkfhjyr0_3643-9300-31} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:25.560505 [ 23593 ] {02434_insert_test_dkfhjyr0_31695-10059-30} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:42274). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:25.560742 [ 23593 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:25.588310 [ 14974 ] {02434_insert_test_dkfhjyr0_3643-9300-31} executeQuery: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:42290) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:25.589321 [ 14974 ] {02434_insert_test_dkfhjyr0_3643-9300-31} DynamicQueryHandler: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:25.589492 [ 14974 ] {02434_insert_test_dkfhjyr0_3643-9300-31} DynamicQueryHandler: Cannot send exception to client: Code: 27. DB::Exception: Cannot parse input: expected '\r\n' at end of stream. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dbfd7 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:25.589725 [ 14974 ] {02434_insert_test_dkfhjyr0_3643-9300-31} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:42290). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:25.590109 [ 14974 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:26.805620 [ 1482 ] {02434_insert_test_dkfhjyr0_415-8406-32} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:27.488990 [ 23621 ] {02434_insert_test_dkfhjyr0_415-8406-32} executeQuery: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:42302) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:27.490117 [ 23621 ] {02434_insert_test_dkfhjyr0_415-8406-32} DynamicQueryHandler: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:27.490366 [ 23621 ] {02434_insert_test_dkfhjyr0_415-8406-32} DynamicQueryHandler: Cannot send exception to client: Code: 27. DB::Exception: Cannot parse input: expected '\r\n' at end of stream. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dbfd7 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:27.490638 [ 23621 ] {02434_insert_test_dkfhjyr0_415-8406-32} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:42302). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:27.490877 [ 23621 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:27.553342 [ 11450 ] {02434_insert_test_dkfhjyr0_24690-600-33} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:27.918009 [ 5753 ] {02434_insert_test_dkfhjyr0_24690-600-33} executeQuery: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:42306) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:27.930147 [ 5753 ] {02434_insert_test_dkfhjyr0_24690-600-33} DynamicQueryHandler: Code: 3. DB::Exception: Unexpected end of file while reading chunk header of HTTP chunked data: While executing ParallelParsingBlockInputFormat. (UNEXPECTED_END_OF_FILE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbcb1 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 16. DB::ReadBuffer::next() @ 0x0000000018778250 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 18. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 19. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 20. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:27.930323 [ 5753 ] {02434_insert_test_dkfhjyr0_24690-600-33} DynamicQueryHandler: Cannot send exception to client: Code: 27. DB::Exception: Cannot parse input: expected '\r\n' at end of stream. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./build_docker/./src/IO/ReadHelpers.cpp:129: ? @ 0x000000002470718e 6. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dbfd7 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:27.930662 [ 5753 ] {02434_insert_test_dkfhjyr0_24690-600-33} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:42306). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:27.930885 [ 5753 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:28.509210 [ 1658 ] {a9d164cd-6782-4666-9216-535505865f38} DynamicQueryHandler: Poco::Exception. Code: 1000, e.code() = 0, Not found: boundary, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:146: Poco::NotFoundException::NotFoundException(String const&, int) @ 0x0000000036980f7b 3. ./build_docker/./base/poco/Net/src/NameValueCollection.cpp:65: Poco::Net::NameValueCollection::operator[](String const&) const @ 0x000000003678f333 4. ./build_docker/./src/Server/HTTP/HTMLForm.cpp:103: DB::HTMLForm::load(Poco::Net::HTTPRequest const&, DB::ReadBuffer&, DB::HTMLForm::PartHandler&) @ 0x00000000334ccdf0 5. ./build_docker/./src/Server/HTTPHandler.cpp:1168: DB::DynamicQueryHandler::getQuery(DB::HTTPServerRequest&, DB::HTMLForm&, std::shared_ptr) @ 0x00000000333de174 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d1b91 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:28.539546 [ 1658 ] {a9d164cd-6782-4666-9216-535505865f38} DynamicQueryHandler: Cannot send exception to client: Code: 69. DB::Exception: Chunk size exceeded the limit (max size: 107374182400). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x00000000192fbcfb 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:0: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x00000000334dbb6f 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x00000000334dc01d 6. DB::ReadBuffer::next() @ 0x0000000018778250 7. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:28.539956 [ 1658 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:28.995765 [ 23601 ] {44865b48-193e-4021-8d8f-be4feacd4624} executeQuery: Code: 36. DB::Exception: Cannot add new database replica: provided path /clickhouse/tables/test_test_867ck5qj/s1/local_t_l5ydey already contains some data and it does not look like Replicated database path. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44202) (comment: 02400_create_table_on_cluster_normalization.sql) (in query: create database local_t_l5ydey engine=Replicated('/clickhouse/tables/test_' || currentDatabase() || '/{shard}/local_t_l5ydey', '1', '1');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:503: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002f77cd98 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:399: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f777e1b 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:543: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f77df1b 7. ./build_docker/./src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000307e5d1a 8. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000307a97ca 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000307d565a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:28.995944 [ 23601 ] {44865b48-193e-4021-8d8f-be4feacd4624} TCPHandler: Code: 36. DB::Exception: Cannot add new database replica: provided path /clickhouse/tables/test_test_867ck5qj/s1/local_t_l5ydey already contains some data and it does not look like Replicated database path. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:503: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000002f77cd98 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:399: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f777e1b 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:543: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f77df1b 7. ./build_docker/./src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000307e5d1a 8. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000307a97ca 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000307d565a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:29.282161 [ 1658 ] {02434_insert_test_dkfhjyr0_18249-28960-36} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:44212). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:44212) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test settings max_insert_block_size=110000, min_insert_block_size_rows=110000 format TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::readDataNext() @ 0x00000000334a89b2 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0813 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:29.283052 [ 1658 ] {02434_insert_test_dkfhjyr0_18249-28960-36} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:44212). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:29.283131 [ 1658 ] {02434_insert_test_dkfhjyr0_18249-28960-36} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:44212). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::readDataNext() @ 0x00000000334a89b2 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0813 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:29.283325 [ 1658 ] {02434_insert_test_dkfhjyr0_18249-28960-36} TCPHandler: Client has gone away. 2025.03.05 21:11:29.511425 [ 23620 ] {02434_insert_test_dkfhjyr0_22952-20466-23} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:51070). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:29.511702 [ 23620 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:29.900952 [ 23586 ] {6f44477a-e607-4434-96f0-8d696b0db9d9} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22+01:02:03' as Date: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate('2022-08-22+01:02:03'). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:54348) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (in query: SELECT toDate('2022-08-22+01:02:03');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x00000000186545d2 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018643e8d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:29.901224 [ 23586 ] {6f44477a-e607-4434-96f0-8d696b0db9d9} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22+01:02:03' as Date: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate('2022-08-22+01:02:03'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x00000000186545d2 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018643e8d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:29.932793 [ 23586 ] {0c1d60e8-45df-44ff-8d6e-8e587e119c35} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22+01:02:03' as Date32: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate32('2022-08-22+01:02:03'). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:54348) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (in query: SELECT toDate32('2022-08-22+01:02:03');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x0000000018476513 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018464d4d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018462def 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:29.933045 [ 23586 ] {0c1d60e8-45df-44ff-8d6e-8e587e119c35} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22+01:02:03' as Date32: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate32('2022-08-22+01:02:03'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x0000000018476513 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018464d4d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018462def 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:29.935291 [ 23586 ] {bb2b20e1-06e7-4e65-8c5b-b06da0089140} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:0' as Date: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate('2022-08-22 01:02:0'). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:54348) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (in query: SELECT toDate('2022-08-22 01:02:0');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x00000000186545d2 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018643e8d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:29.935445 [ 23586 ] {bb2b20e1-06e7-4e65-8c5b-b06da0089140} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:0' as Date: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate('2022-08-22 01:02:0'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x00000000186545d2 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018643e8d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:29.937556 [ 23586 ] {a1089817-840a-49ab-baf9-be48a37b88f2} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:0' as Date32: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate32('2022-08-22 01:02:0'). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:54348) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (in query: SELECT toDate32('2022-08-22 01:02:0');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x0000000018476513 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018464d4d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018462def 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:29.937767 [ 23586 ] {a1089817-840a-49ab-baf9-be48a37b88f2} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:0' as Date32: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate32('2022-08-22 01:02:0'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x0000000018476513 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018464d4d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018462def 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:29.940820 [ 23586 ] {c1050482-44b0-4e76-8f56-5c75aaf13ff1} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.' as Date: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate('2022-08-22 01:02:03.'). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:54348) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (in query: SELECT toDate('2022-08-22 01:02:03.');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x00000000186545d2 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018643e8d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:29.941071 [ 23586 ] {c1050482-44b0-4e76-8f56-5c75aaf13ff1} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.' as Date: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate('2022-08-22 01:02:03.'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x00000000186545d2 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018643e8d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:29.944038 [ 23586 ] {83c2aa8e-dea5-4d01-8949-a7636524a48c} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.' as Date32: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate32('2022-08-22 01:02:03.'). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:54348) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (in query: SELECT toDate32('2022-08-22 01:02:03.');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x0000000018476513 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018464d4d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018462def 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:29.944347 [ 23586 ] {83c2aa8e-dea5-4d01-8949-a7636524a48c} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.' as Date32: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate32('2022-08-22 01:02:03.'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x0000000018476513 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018464d4d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018462def 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:29.947002 [ 23586 ] {87700e36-cf8a-488c-b18e-c62d7f028602} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.111a' as Date: syntax error at position 23 (parsed just '2022-08-22 01:02:03.111'): In scope SELECT toDate('2022-08-22 01:02:03.111a'). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:54348) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (in query: SELECT toDate('2022-08-22 01:02:03.111a');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x00000000186545d2 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018643e8d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:29.947187 [ 23586 ] {87700e36-cf8a-488c-b18e-c62d7f028602} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.111a' as Date: syntax error at position 23 (parsed just '2022-08-22 01:02:03.111'): In scope SELECT toDate('2022-08-22 01:02:03.111a'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x00000000186545d2 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018643e8d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:29.949254 [ 23586 ] {d38f85b4-d909-47d8-84bf-29f3ab084192} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.2b' as Date32: syntax error at position 21 (parsed just '2022-08-22 01:02:03.2'): In scope SELECT toDate32('2022-08-22 01:02:03.2b'). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:54348) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (in query: SELECT toDate32('2022-08-22 01:02:03.2b');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x0000000018476513 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018464d4d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018462def 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:29.949426 [ 23586 ] {d38f85b4-d909-47d8-84bf-29f3ab084192} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.2b' as Date32: syntax error at position 21 (parsed just '2022-08-22 01:02:03.2'): In scope SELECT toDate32('2022-08-22 01:02:03.2b'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x0000000018476513 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018464d4d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018462def 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:29.951194 [ 23586 ] {10145120-296b-4bd2-b9dd-b3f5eeb8ba02} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.a' as Date: syntax error at position 20 (parsed just '2022-08-22 01:02:03.'): In scope SELECT toDate('2022-08-22 01:02:03.a'). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:54348) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (in query: SELECT toDate('2022-08-22 01:02:03.a');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x00000000186545d2 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018643e8d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:29.951380 [ 23586 ] {10145120-296b-4bd2-b9dd-b3f5eeb8ba02} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.a' as Date: syntax error at position 20 (parsed just '2022-08-22 01:02:03.'): In scope SELECT toDate('2022-08-22 01:02:03.a'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x00000000186545d2 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018643e8d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:29.953840 [ 23586 ] {b5521499-8792-4f8f-89c5-772f879d67f1} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.b' as Date32: syntax error at position 20 (parsed just '2022-08-22 01:02:03.'): In scope SELECT toDate32('2022-08-22 01:02:03.b'). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:54348) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (in query: SELECT toDate32('2022-08-22 01:02:03.b');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x0000000018476513 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018464d4d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018462def 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:29.954018 [ 23586 ] {b5521499-8792-4f8f-89c5-772f879d67f1} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.b' as Date32: syntax error at position 20 (parsed just '2022-08-22 01:02:03.'): In scope SELECT toDate32('2022-08-22 01:02:03.b'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x0000000018476513 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018464d4d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018462def 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:11:30.189179 [ 23586 ] {c00b1ad5-5862-4199-bc96-bc542ff94479} executeQuery: Code: 1. DB::Exception: Recursive lambda x -> (lambda(1) + x) AS lambda. In scope x -> (lambda(1) + x) AS lambda. (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:54364) (comment: 02388_analyzer_recursive_lambda.sql) (in query: WITH x -> plus(lambda(1), x) AS lambda SELECT lambda(1048576);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c163e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b4694 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c0fcf 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b4694 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:11:30.189389 [ 23586 ] {c00b1ad5-5862-4199-bc96-bc542ff94479} TCPHandler: Code: 1. DB::Exception: Recursive lambda x -> (lambda(1) + x) AS lambda. In scope x -> (lambda(1) + x) AS lambda. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c163e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b4694 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c0fcf 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b4694 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:11:30.192518 [ 23586 ] {602955a9-eda7-42f3-8d00-dc260e172414} executeQuery: Code: 1. DB::Exception: Recursive lambda x -> plus(lambda(1), x, 2) AS lambda. In scope x -> plus(lambda(1), x, 2) AS lambda. (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:54364) (comment: 02388_analyzer_recursive_lambda.sql) (in query: WITH lambda(lambda(plus(x, x, -1)), tuple(x), x + 2147483646) AS lambda, x -> plus(lambda(1), x, 2) AS lambda SELECT 1048576, lambda(1048576);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c163e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b4694 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c0fcf 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b4694 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:11:30.192668 [ 23586 ] {602955a9-eda7-42f3-8d00-dc260e172414} TCPHandler: Code: 1. DB::Exception: Recursive lambda x -> plus(lambda(1), x, 2) AS lambda. In scope x -> plus(lambda(1), x, 2) AS lambda. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c163e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b4694 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c0fcf 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b4694 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:11:30.370059 [ 1861 ] {f7a388e7-3b45-4e7f-b0f2-29c260cb1ef4} ExternalDictionariesLoader: Could not load external dictionary 'ae40730c-5b78-4206-a3c9-b5eceba6f809', next update is scheduled at 2025-03-05 21:11:35: Code: 36. DB::Exception: ae40730c-5b78-4206-a3c9-b5eceba6f809: SHARDS parameter does not supports for updatable source (UPDATE_FIELD). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:84: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x00000000295d6f26 5. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:125: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x00000000295d7a6d 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e831b7d 7. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830dc0 8. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 12. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:30.370398 [ 22863 ] {f7a388e7-3b45-4e7f-b0f2-29c260cb1ef4} executeQuery: Code: 36. DB::Exception: ae40730c-5b78-4206-a3c9-b5eceba6f809: SHARDS parameter does not supports for updatable source (UPDATE_FIELD). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:54296) (comment: 02391_hashed_dictionary_shards.sql) (in query: SYSTEM RELOAD DICTIONARY test_dictionary_10_shards_incremental;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:84: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x00000000295d6f26 5. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:125: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x00000000295d7a6d 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e831b7d 7. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830dc0 8. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 12. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:30.370595 [ 22863 ] {f7a388e7-3b45-4e7f-b0f2-29c260cb1ef4} TCPHandler: Code: 36. DB::Exception: ae40730c-5b78-4206-a3c9-b5eceba6f809: SHARDS parameter does not supports for updatable source (UPDATE_FIELD). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:84: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x00000000295d6f26 5. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:125: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x00000000295d7a6d 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e831b7d 7. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:0: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830dc0 8. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 12. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:30.526425 [ 23642 ] {02434_insert_test_dkfhjyr0_8279-21273-24} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:42174). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:30.526654 [ 23642 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:30.846409 [ 23586 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:30.970856 [ 23612 ] {e46900bd-70c9-4120-aaba-2576d3d24ac4} executeQuery: Code: 43. DB::Exception: Illegal type of argument #2 'input' of function decrypt, expected ciphertext, got Array(Nullable(UInt64)): In scope SELECT decrypt('aes-128-gcm', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:54484) (comment: 02384_decrypt_bad_arguments.sql) (in query: SELECT decrypt('aes-128-gcm', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa9974b 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:30.971057 [ 23612 ] {e46900bd-70c9-4120-aaba-2576d3d24ac4} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #2 'input' of function decrypt, expected ciphertext, got Array(Nullable(UInt64)): In scope SELECT decrypt('aes-128-gcm', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa9974b 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:31.471782 [ 23612 ] {7bcfc2e9-590f-4bb1-a415-55f95b7d7051} executeQuery: Code: 162. DB::Exception: Too deep subqueries. Maximum: 1. (TOO_DEEP_SUBQUERIES) (version 24.3.12.76.altinitystable) (from [::1]:54528) (comment: 02379_analyzer_subquery_depth.sql) (in query: SELECT (SELECT a FROM (SELECT 1 AS a)) SETTINGS max_subquery_depth = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000001904abbb 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030877c0d 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6519: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882639 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7911: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd42 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6519: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882639 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:31.472008 [ 23612 ] {7bcfc2e9-590f-4bb1-a415-55f95b7d7051} TCPHandler: Code: 162. DB::Exception: Too deep subqueries. Maximum: 1. (TOO_DEEP_SUBQUERIES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000001904abbb 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030877c0d 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6519: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882639 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7911: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd42 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6519: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882639 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:31.580163 [ 1859 ] {02434_insert_test_dkfhjyr0_17336-9047-39} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 33. DB::Exception: Unexpected EOF, got 23527424 of 38888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:31.721953 [ 23587 ] {0e0380c0-6e77-45d4-b177-c22106781436} executeQuery: Code: 43. DB::Exception: Illegal type of argument 'structure' for table function 'executable': must be an identifier or string literal. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:54544) (comment: 02377_executable_function_settings.sql) (in query: SELECT * from executable('JSON', 'data String', SETTINGS max_command_execution_time=100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:0: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr)::$_1::operator()(unsigned long, String const&) const @ 0x000000002e45ff8a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e45cb7e 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:31.722182 [ 23587 ] {0e0380c0-6e77-45d4-b177-c22106781436} TCPHandler: Code: 43. DB::Exception: Illegal type of argument 'structure' for table function 'executable': must be an identifier or string literal. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:0: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr)::$_1::operator()(unsigned long, String const&) const @ 0x000000002e45ff8a 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e45cb7e 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:31.782761 [ 23587 ] {ca99c3b6-6c58-4a09-bcbc-8759e6f9d2cb} executeQuery: Code: 36. DB::Exception: Table function 'executable' argument is invalid 'TEST'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:54544) (comment: 02377_executable_function_settings.sql) (in query: SELECT * from executable('JSON', 'data String', 'TEST', 'TEST');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:0: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e45e06b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:31.793122 [ 23587 ] {ca99c3b6-6c58-4a09-bcbc-8759e6f9d2cb} TCPHandler: Code: 36. DB::Exception: Table function 'executable' argument is invalid 'TEST'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:0: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e45e06b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:32.169725 [ 23606 ] {02434_insert_test_dkfhjyr0_17336-9047-39} executeQuery: Code: 33. DB::Exception: Unexpected EOF, got 23527424 of 38888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:37862) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:32.171054 [ 23606 ] {02434_insert_test_dkfhjyr0_17336-9047-39} DynamicQueryHandler: Code: 33. DB::Exception: Unexpected EOF, got 23527424 of 38888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:32.171196 [ 23606 ] {02434_insert_test_dkfhjyr0_17336-9047-39} DynamicQueryHandler: Cannot send exception to client: Code: 33. DB::Exception: Unexpected EOF, got 23789568 of 38888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:32.171435 [ 23606 ] {02434_insert_test_dkfhjyr0_17336-9047-39} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:37862). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:32.171662 [ 23606 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:32.175297 [ 23498 ] {df7d146e-19fe-4488-8757-79a2e907d7bc} executeQuery: Code: 289. DB::Exception: Replica doesn't have part '20181115_0_0_0' which was successfully written to quorum of other replicas. Send query to another replica or disable 'select_sequential_consistency' setting. (REPLICA_IS_NOT_IN_QUORUM) (version 24.3.12.76.altinitystable) (from [::1]:54548) (comment: 02377_majority_insert_quorum_zookeeper_long.sql) (in query: SELECT x FROM quorum3 ORDER BY x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5395: DB::StorageReplicatedMergeTree::getMaxAddedBlocks() const @ 0x0000000032492cb4 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::readLocalSequentialConsistencyImpl(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, unsigned long, unsigned long) @ 0x000000003249386e 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5425: DB::StorageReplicatedMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000324934e6 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 9. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:32.175490 [ 23498 ] {df7d146e-19fe-4488-8757-79a2e907d7bc} TCPHandler: Code: 289. DB::Exception: Replica doesn't have part '20181115_0_0_0' which was successfully written to quorum of other replicas. Send query to another replica or disable 'select_sequential_consistency' setting. (REPLICA_IS_NOT_IN_QUORUM), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5395: DB::StorageReplicatedMergeTree::getMaxAddedBlocks() const @ 0x0000000032492cb4 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::readLocalSequentialConsistencyImpl(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, unsigned long, unsigned long) @ 0x000000003249386e 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5425: DB::StorageReplicatedMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000324934e6 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 9. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:32.415061 [ 11447 ] {02434_insert_test_dkfhjyr0_1298-28472-40} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 33. DB::Exception: Unexpected EOF, got 23330816 of 38888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:32.643557 [ 23586 ] {02434_insert_test_dkfhjyr0_1298-28472-40} executeQuery: Code: 33. DB::Exception: Unexpected EOF, got 23330816 of 38888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:37890) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:32.644630 [ 23586 ] {02434_insert_test_dkfhjyr0_1298-28472-40} DynamicQueryHandler: Code: 33. DB::Exception: Unexpected EOF, got 23330816 of 38888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:32.644833 [ 23586 ] {02434_insert_test_dkfhjyr0_1298-28472-40} DynamicQueryHandler: Cannot send exception to client: Code: 33. DB::Exception: Unexpected EOF, got 24379392 of 38888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:32.645109 [ 23586 ] {02434_insert_test_dkfhjyr0_1298-28472-40} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:37890). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:32.645319 [ 23586 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:33.231177 [ 23590 ] {02434_insert_test_dkfhjyr0_21222-14931-29} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:42260). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:33.231398 [ 23590 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:33.762782 [ 23622 ] {02434_insert_test_dkfhjyr0_2904-26539-34} DynamicQueryHandler: Cannot flush data to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:42312). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d2916 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:33.763071 [ 23622 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:35.061501 [ 23619 ] {f1144702-3c36-4eb0-9395-1357dea1dba4} executeQuery: Code: 456. DB::Exception: Substitution `n` is not set. (UNKNOWN_QUERY_PARAMETER) (version 24.3.12.76.altinitystable) (from [::1]:54820) (comment: 02377_extend_protocol_with_query_parameters.sh) (in query: select {n: UInt8} -- { serverError 456 }), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::getParamValue(String const&) @ 0x00000000316d362e 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x00000000316d03b9 6. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000316d33b9 7. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000316d33b9 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000316d33b9 9. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000316d33b9 10. ./build_docker/./src/Interpreters/executeQuery.cpp:821: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f6d3e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:35.061688 [ 23619 ] {f1144702-3c36-4eb0-9395-1357dea1dba4} TCPHandler: Code: 456. DB::Exception: Substitution `n` is not set. (UNKNOWN_QUERY_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::getParamValue(String const&) @ 0x00000000316d362e 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x00000000316d03b9 6. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000316d33b9 7. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000316d33b9 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000316d33b9 9. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000316d33b9 10. ./build_docker/./src/Interpreters/executeQuery.cpp:821: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f6d3e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:36.324657 [ 6306 ] {02434_insert_test_dkfhjyr0_30480-30136-46} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 33. DB::Exception: Unexpected EOF, got 22740992 of 38888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:36.347835 [ 23628 ] {02434_insert_test_dkfhjyr0_22152-15670-47} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:54978). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:54978) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test settings max_insert_block_size=110000, min_insert_block_size_rows=110000 format TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::readDataNext() @ 0x00000000334a89b2 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0813 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:36.348432 [ 23628 ] {02434_insert_test_dkfhjyr0_22152-15670-47} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:54978). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:36.348473 [ 23628 ] {02434_insert_test_dkfhjyr0_22152-15670-47} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:54978). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::readDataNext() @ 0x00000000334a89b2 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0813 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:36.348623 [ 23628 ] {02434_insert_test_dkfhjyr0_22152-15670-47} TCPHandler: Client has gone away. 2025.03.05 21:11:36.433094 [ 23635 ] {02434_insert_test_dkfhjyr0_30480-30136-46} executeQuery: Code: 33. DB::Exception: Unexpected EOF, got 22740992 of 38888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:37904) (comment: 02434_cancel_insert_when_client_dies.sh) (in query: insert into dedup_test format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:36.434242 [ 23635 ] {02434_insert_test_dkfhjyr0_30480-30136-46} DynamicQueryHandler: Code: 33. DB::Exception: Unexpected EOF, got 22740992 of 38888890 bytes: While executing ParallelParsingBlockInputFormat. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 7. DB::ReadBuffer::next() @ 0x0000000018778250 8. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 9. DB::ReadBuffer::next() @ 0x0000000018778250 10. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 11. DB::ReadBuffer::next() @ 0x0000000018778250 12. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 13. DB::ReadBuffer::next() @ 0x0000000018778250 14. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc146df 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: DB::loadAtPosition(DB::ReadBuffer&, DB::Memory>&, char*&) @ 0x000000002470a00e 17. ./build_docker/./src/Processors/Formats/Impl/TabSeparatedRowInputFormat.cpp:449: DB::fileSegmentationEngineTabSeparatedImpl(DB::ReadBuffer&, DB::Memory>&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033ab9bde 18. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x00000000338bbd86 19. ./contrib/llvm-project/libcxx/include/tuple:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000338c3d56 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:36.434431 [ 23635 ] {02434_insert_test_dkfhjyr0_30480-30136-46} DynamicQueryHandler: Cannot send exception to client: Code: 33. DB::Exception: Unexpected EOF, got 23265280 of 38888890 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. ./build_docker/./src/IO/LimitReadBuffer.cpp:39: DB::LimitReadBuffer::nextImpl() @ 0x00000000249924b2 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/HTTPHandler.cpp:989: DB::HTTPHandler::formatExceptionForClient(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6986 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d5c89 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:36.434748 [ 23635 ] {02434_insert_test_dkfhjyr0_30480-30136-46} DynamicQueryHandler: Cannot flush data to client (after sending exception): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:37904). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x0000000024881d31 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:52: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x00000000334e4e09 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:89: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x00000000334e59a2 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x00000000334e7014 8. DB::WriteBuffer::finalize() @ 0x0000000018076036 9. ./build_docker/./src/Server/HTTPHandler.cpp:976: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x00000000333d6430 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333dba75 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:36.434987 [ 23635 ] {} ServerErrorHandler: Poco::Exception. Code: 1000, e.code() = 107, Net Exception: Socket is not connected, Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:164: Poco::IOException::IOException(String const&, int) @ 0x0000000036987a5b 3. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::NetException::NetException(String const&, int) @ 0x0000000036790cf6 4. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000367abae9 5. ./contrib/llvm-project/libcxx/include/string:1499: Poco::Net::SocketImpl::error() @ 0x00000000367ab71f 6. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:601: Poco::Net::SocketImpl::peerAddress() @ 0x00000000367b1691 7. ./build_docker/./base/poco/Net/src/HTTPServerSession.cpp:65: Poco::Net::HTTPServerSession::clientAddress() @ 0x0000000036773c63 8. ./build_docker/./src/Server/HTTP/HTTPServerRequest.cpp:0: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x00000000334d72f2 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:37: DB::HTTPServerConnection::run() @ 0x00000000334d489b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:37.242768 [ 23498 ] {c11417f5-5283-4920-82f3-31ae232bf5bb} executeQuery: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT) (version 24.3.12.76.altinitystable) (from [::1]:54548) (comment: 02377_majority_insert_quorum_zookeeper_long.sql) (in query: INSERT INTO quorum1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1189: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x00000000330196f2 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1135: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()::operator()() const @ 0x000000003303e7ed 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003303e2f8 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033016690 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033013e19 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 16. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:37.242950 [ 23498 ] {c11417f5-5283-4920-82f3-31ae232bf5bb} TCPHandler: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1189: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x00000000330196f2 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1135: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()::operator()() const @ 0x000000003303e7ed 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003303e2f8 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033016690 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033013e19 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 16. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:37.680555 [ 730 ] {20cbe47a-7b80-495c-b728-4a3c4a0a4cc1} executeQuery: Code: 207. DB::Exception: JOIN test_lpk8wtrg.test_table_join_1, test_lpk8wtrg.test_table_join_2 ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1, test_table_join_2. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:55202) (comment: 02371_analyzer_join_cross.sql) (in query: SELECT id FROM test_table_join_1, test_table_join_2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cce56 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:37.680721 [ 730 ] {20cbe47a-7b80-495c-b728-4a3c4a0a4cc1} TCPHandler: Code: 207. DB::Exception: JOIN test_lpk8wtrg.test_table_join_1, test_lpk8wtrg.test_table_join_2 ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1, test_table_join_2. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cce56 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:37.682531 [ 730 ] {f1ef9097-30e5-4a45-8b58-b8dea059cf8b} executeQuery: Code: 207. DB::Exception: JOIN test_lpk8wtrg.test_table_join_1, test_lpk8wtrg.test_table_join_2 ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1, test_table_join_2. (AMBIGUOUS_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:55202) (comment: 02371_analyzer_join_cross.sql) (in query: SELECT value FROM test_table_join_1, test_table_join_2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cce56 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:37.682664 [ 730 ] {f1ef9097-30e5-4a45-8b58-b8dea059cf8b} TCPHandler: Code: 207. DB::Exception: JOIN test_lpk8wtrg.test_table_join_1, test_lpk8wtrg.test_table_join_2 ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1, test_table_join_2. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoin(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308cce56 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:3887: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7284 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:38.060528 [ 730 ] {656e8fc2-2173-47fb-9cbd-05b2866883f5} executeQuery: Code: 475. DB::Exception: Incompatible types of WITH FILL expression values with column type Date. (INVALID_WITH_FILL_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:55296) (comment: 02366_with_fill_date.sql) (in query: SELECT toDate('2022-02-01') AS d1 FROM numbers(18) AS number ORDER BY d1 ASC WITH FILL FROM toDateTime('2022-02-01') TO toDateTime('2022-07-01') STEP toIntervalMonth(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:0: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000033ebc086 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], bool const&>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9cac 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9a03 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000033eb8b8f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002f3e3b2e 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f3e38c1 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033eb7db8 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033edaab5 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:38.060695 [ 730 ] {656e8fc2-2173-47fb-9cbd-05b2866883f5} TCPHandler: Code: 475. DB::Exception: Incompatible types of WITH FILL expression values with column type Date. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:0: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000033ebc086 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], bool const&>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9cac 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9a03 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000033eb8b8f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002f3e3b2e 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f3e38c1 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033eb7db8 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033edaab5 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:39.183253 [ 23573 ] {ed333611-b46a-4af4-b67e-cedab545afbe} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT accurateCastOrNull(JSON_VALUE('', ''), 'String'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:55372) (comment: 02366_kql_func_string.sql) (in query: print extract_json('', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180b4365 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b332d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:11:39.183257 [ 23577 ] {c79d9818-9dd9-462c-98d2-4dd6a0c9ae57} executeQuery: Code: 80. DB::Exception: Failed to rewrite ' test_1k5lorca.t1 AS __table1, test_1k5lorca.t2 AS __table2' to INNER JOIN: no equi-join conditions found in WHERE clause. You may set setting `cross_to_inner_join_rewrite` to `1` to allow slow CROSS JOIN for this case. (INCORRECT_QUERY) (version 24.3.12.76.altinitystable) (from [::1]:48568) (comment: 02364_setting_cross_to_inner_rewrite.sql) (in query: SELECT count() = 1 FROM t1, t2 WHERE t1.x > t2.x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:0: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x0000000030f10b9e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CrossToInnerJoinPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030f0e969 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:39.183440 [ 23577 ] {c79d9818-9dd9-462c-98d2-4dd6a0c9ae57} TCPHandler: Code: 80. DB::Exception: Failed to rewrite ' test_1k5lorca.t1 AS __table1, test_1k5lorca.t2 AS __table2' to INNER JOIN: no equi-join conditions found in WHERE clause. You may set setting `cross_to_inner_join_rewrite` to `1` to allow slow CROSS JOIN for this case. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:0: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x0000000030f10b9e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CrossToInnerJoinPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000030f0e969 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:39.183484 [ 23573 ] {ed333611-b46a-4af4-b67e-cedab545afbe} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT accurateCastOrNull(JSON_VALUE('', ''), 'String'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180b4365 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b332d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:11:39.185646 [ 23573 ] {5bbf1c3f-13cc-4347-84b8-0d3523627e5e} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT accurateCastOrNull(JSON_VALUE('', 'a'), 'String'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:55372) (comment: 02366_kql_func_string.sql) (in query: print extract_json('a', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180b4365 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b332d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:11:39.185778 [ 23573 ] {5bbf1c3f-13cc-4347-84b8-0d3523627e5e} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT accurateCastOrNull(JSON_VALUE('', 'a'), 'String'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180b4365 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b332d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:11:39.291579 [ 23573 ] {56d313f5-934b-4a05-9d2d-00e7701ff695} executeQuery: Code: 395. DB::Exception: Expected guid as argument: while executing 'FUNCTION if(_CAST(1_UInt8, 'UInt8'_String) :: 1, toString(throwIf(_CAST(true_Bool, 'Bool'_String), 'Expected guid as argument'_String)) :: 3, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String) :: 4) -> if(_CAST(1_UInt8, 'UInt8'_String), toString(throwIf(_CAST(true_Bool, 'Bool'_String), 'Expected guid as argument'_String)), _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)) Nullable(String) : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:55372) (comment: 02366_kql_func_string.sql) (in query: print base64_encode_fromguid(dynamic(null));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::createRuntime(int, String const&) @ 0x00000000219cd07f 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9dbb 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ColumnFunction::reduce() const @ 0x0000000031b24117 11. ./build_docker/./src/Columns/ColumnFunction.cpp:311: DB::ColumnFunction::reduce() const @ 0x0000000031b23d27 12. ./build_docker/./src/Columns/MaskOperations.cpp:310: DB::executeColumnIfNeeded(DB::ColumnWithTypeAndName&, bool) @ 0x00000000320620cb 13. ./contrib/llvm-project/libcxx/include/vector:1457: DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000309d2a78 14. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 17. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:39.291717 [ 23573 ] {56d313f5-934b-4a05-9d2d-00e7701ff695} TCPHandler: Code: 395. DB::Exception: Expected guid as argument: while executing 'FUNCTION if(_CAST(1_UInt8, 'UInt8'_String) :: 1, toString(throwIf(_CAST(true_Bool, 'Bool'_String), 'Expected guid as argument'_String)) :: 3, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String) :: 4) -> if(_CAST(1_UInt8, 'UInt8'_String), toString(throwIf(_CAST(true_Bool, 'Bool'_String), 'Expected guid as argument'_String)), _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)) Nullable(String) : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::createRuntime(int, String const&) @ 0x00000000219cd07f 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9dbb 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ColumnFunction::reduce() const @ 0x0000000031b24117 11. ./build_docker/./src/Columns/ColumnFunction.cpp:311: DB::ColumnFunction::reduce() const @ 0x0000000031b23d27 12. ./build_docker/./src/Columns/MaskOperations.cpp:310: DB::executeColumnIfNeeded(DB::ColumnWithTypeAndName&, bool) @ 0x00000000320620cb 13. ./contrib/llvm-project/libcxx/include/vector:1457: DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000309d2a78 14. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 17. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:39.311406 [ 23573 ] {18f2f919-80a1-495f-aff9-17044d94f1f6} executeQuery: Code: 395. DB::Exception: Expected guid as argument: while executing 'FUNCTION throwIf(_CAST(true_Bool, 'Bool'_String) :: 1, 'Expected guid as argument'_String :: 2) -> throwIf(_CAST(true_Bool, 'Bool'_String), 'Expected guid as argument'_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:55372) (comment: 02366_kql_func_string.sql) (in query: print base64_encode_fromguid("abcd1231");), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::createRuntime(int, String const&) @ 0x00000000219cd07f 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9dbb 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:39.311589 [ 23573 ] {18f2f919-80a1-495f-aff9-17044d94f1f6} TCPHandler: Code: 395. DB::Exception: Expected guid as argument: while executing 'FUNCTION throwIf(_CAST(true_Bool, 'Bool'_String) :: 1, 'Expected guid as argument'_String :: 2) -> throwIf(_CAST(true_Bool, 'Bool'_String), 'Expected guid as argument'_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::createRuntime(int, String const&) @ 0x00000000219cd07f 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9dbb 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:39.486816 [ 23573 ] {dc9ef265-78f4-4ae0-ad39-b5c8d8dd2e2b} executeQuery: Code: 43. DB::Exception: Illegal type of argument #2 's' of function splitByChar, expected String, got UInt8: In scope SELECT if((length(splitByChar('.', 42)) > 4) OR (length(splitByChar('.', 42)) < 1) OR (match(42, '.*[a-zA-Z]+.*') = 1), toDecimal128OrNull('NULL', 0), toDecimal128OrNull(substring(arrayStringConcat(arrayMap(x -> leftPad(x, 8, '0'), arrayMap(x -> if(empty(x), '0', x), arrayResize(splitByChar('.', 42), 4)))), 8), 0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:55372) (comment: 02366_kql_func_string.sql) (in query: print parse_version(42);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021638ca2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a6916 22. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 25. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:11:39.487058 [ 23573 ] {dc9ef265-78f4-4ae0-ad39-b5c8d8dd2e2b} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #2 's' of function splitByChar, expected String, got UInt8: In scope SELECT if((length(splitByChar('.', 42)) > 4) OR (length(splitByChar('.', 42)) < 1) OR (match(42, '.*[a-zA-Z]+.*') = 1), toDecimal128OrNull('NULL', 0), toDecimal128OrNull(substring(arrayStringConcat(arrayMap(x -> leftPad(x, 8, '0'), arrayMap(x -> if(empty(x), '0', x), arrayResize(splitByChar('.', 42), 4)))), 8), 0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021638ca2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a6916 22. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 25. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:11:39.578239 [ 23573 ] {0d0a7ccd-a732-4689-88c1-2c9e661da770} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function empty: In scope SELECT if(empty(55) OR hasAll(splitByChar(' ', 55), ['']), arrayMap(x -> NULL, splitByChar(' ', '')), splitByChar(' ', 55)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:55372) (comment: 02366_kql_func_string.sql) (in query: print parse_command_line(55, 'windows');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionStringOrArrayToT, DB::(anonymous namespace)::NameEmpty, char8_t, false>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b1359a7 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a6916 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:11:39.578529 [ 23573 ] {0d0a7ccd-a732-4689-88c1-2c9e661da770} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function empty: In scope SELECT if(empty(55) OR hasAll(splitByChar(' ', 55), ['']), arrayMap(x -> NULL, splitByChar(' ', '')), splitByChar(' ', 55)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionStringOrArrayToT, DB::(anonymous namespace)::NameEmpty, char8_t, false>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b1359a7 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a6916 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:11:39.649987 [ 23573 ] {fb878dd8-dff0-4261-80b5-68d77adca279} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function position: In scope SELECT if(CAST(position(65, '\n'), 'UInt8'), splitByChar(',', substring(65, 1, position(65, '\n') - 1)), splitByChar(',', substring(65, 1, length(65)))). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:55372) (comment: 02366_kql_func_string.sql) (in query: print parse_csv(65);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002126325c 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a6916 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:11:39.650283 [ 23573 ] {fb878dd8-dff0-4261-80b5-68d77adca279} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function position: In scope SELECT if(CAST(position(65, '\n'), 'UInt8'), splitByChar(',', substring(65, 1, position(65, '\n') - 1)), splitByChar(',', substring(65, 1, length(65)))). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002126325c 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a6916 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:11:41.268138 [ 23577 ] {6f56bf64-4529-421d-928c-22814a37ed93} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 256, should be at most 255. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:48578) (comment: 02364_multiSearch_function_family.sql) (in query: select multiSearchAllPositions(materialize('string'), ['o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'str']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, unsigned long&&) @ 0x000000001fd3a8e2 4. DB::FunctionsMultiStringPosition>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd39d11 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:41.268420 [ 23577 ] {6f56bf64-4529-421d-928c-22814a37ed93} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 256, should be at most 255. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, unsigned long&&) @ 0x000000001fd3a8e2 4. DB::FunctionsMultiStringPosition>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd39d11 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:41.298993 [ 23577 ] {33f8bbda-8717-4986-9a41-2a067a40daad} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 256, should be at most 255. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:48578) (comment: 02364_multiSearch_function_family.sql) (in query: select multiSearchFirstIndex(materialize('string'), ['o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'str']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const* const&, String&&, String&&) @ 0x000000001fd62d91 4. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd621e6 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:41.299384 [ 23577 ] {33f8bbda-8717-4986-9a41-2a067a40daad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 256, should be at most 255. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const* const&, String&&, String&&) @ 0x000000001fd62d91 4. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd621e6 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:41.443267 [ 22863 ] {421660a1-7270-45d4-aa4e-4df38431761d} executeQuery: Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/user_files/nonexistent.txt: , errno: 2, strerror: No such file or directory: In scope SELECT file('nonexistent.txt'). (FILE_DOESNT_EXIST) (version 24.3.12.76.altinitystable) (from [::1]:48920) (comment: 02357_file_default_value.sql) (in query: SELECT file('nonexistent.txt');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::ErrnoException::ErrnoException(String&&, int, int) @ 0x00000000246e5d9f 4. ./contrib/llvm-project/libcxx/include/string:1499: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&) @ 0x00000000246fabc9 5. ./build_docker/./src/IO/ReadBufferFromFile.cpp:48: DB::ReadBufferFromFile::ReadBufferFromFile(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x00000000246ffa8a 6. DB::FunctionFile::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001807346e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:11:41.443619 [ 22863 ] {421660a1-7270-45d4-aa4e-4df38431761d} TCPHandler: Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/user_files/nonexistent.txt: , errno: 2, strerror: No such file or directory: In scope SELECT file('nonexistent.txt'). (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::ErrnoException::ErrnoException(String&&, int, int) @ 0x00000000246e5d9f 4. ./contrib/llvm-project/libcxx/include/string:1499: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&) @ 0x00000000246fabc9 5. ./build_docker/./src/IO/ReadBufferFromFile.cpp:48: DB::ReadBufferFromFile::ReadBufferFromFile(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x00000000246ffa8a 6. DB::FunctionFile::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001807346e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:11:41.689584 [ 23597 ] {c7ecc257-a0d7-4626-9c2d-63e5732e21a7} executeQuery: Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/store/3b7/3b7524a2-72f7-4e5f-80a3-366020504bac/all_0_1_1/data.bin: , errno: 2, strerror: No such file or directory: (while reading from part /var/lib/clickhouse/store/3b7/3b7524a2-72f7-4e5f-80a3-366020504bac/all_0_1_1/ in table test_rty5xhw6.rmt1 (3b7524a2-72f7-4e5f-80a3-366020504bac) located on disk default of type local, from mark 0 with max_rows_to_read = 2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (FILE_DOESNT_EXIST) (version 24.3.12.76.altinitystable) (from [::1]:48976) (comment: 02369_lost_part_intersecting_merges.sh) (in query: select * from rmt1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::ErrnoException::ErrnoException(String&&, int, int) @ 0x00000000246e5d9f 4. ./contrib/llvm-project/libcxx/include/string:1499: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x00000000246e5b89 5. ./build_docker/./src/IO/OpenedFile.cpp:33: DB::OpenedFile::open() const @ 0x000000002e901613 6. ./build_docker/./src/IO/OpenedFile.cpp:42: DB::OpenedFile::getFD() const @ 0x000000002e90166d 7. ./src/IO/AsynchronousReadBufferFromFile.h:75: DB::AsynchronousReadBufferFromFileWithDescriptorsCache::AsynchronousReadBufferFromFileWithDescriptorsCache(DB::IAsynchronousReader&, Priority, String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000002e8f93fd 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&>(DB::IOUringReader&, Priority const&, String const&, unsigned long&, int&, char*&, unsigned long&, std::optional&, std::shared_ptr const&) @ 0x000000002e8f5f9c 9. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:111: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x000000002e8f5199 10. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:220: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x000000002e8f4df0 11. ./build_docker/./src/Disks/DiskLocal.cpp:335: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000002f9b546f 12. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:131: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000003297d74e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:76: std::unique_ptr> std::__function::__policy_invoker> ()>::__call_impl> ()>>(std::__function::__policy_storage const*) @ 0x0000000032dc676e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000032dbab6f 15. ./src/Compression/CachedCompressedReadBuffer.h:65: DB::CachedCompressedReadBuffer::setReadUntilPosition(unsigned long) @ 0x0000000032dbe2f2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:37: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000032db8022 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:111: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000032de7c54 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:183: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000032de7dcd 19. ./src/Storages/MergeTree/MergeTreeRangeReader.h:135: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000032df81f7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df4bbe 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:164: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000032e04f6f 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000033f8b134 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:139: DB::MergeTreeSelectProcessor::read() @ 0x0000000032de396f 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:0: DB::MergeTreeSource::tryGenerate() @ 0x0000000033fb1d35 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 30. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 31. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 2025.03.05 21:11:41.709074 [ 23597 ] {c7ecc257-a0d7-4626-9c2d-63e5732e21a7} TCPHandler: Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/store/3b7/3b7524a2-72f7-4e5f-80a3-366020504bac/all_0_1_1/data.bin: , errno: 2, strerror: No such file or directory: (while reading from part /var/lib/clickhouse/store/3b7/3b7524a2-72f7-4e5f-80a3-366020504bac/all_0_1_1/ in table test_rty5xhw6.rmt1 (3b7524a2-72f7-4e5f-80a3-366020504bac) located on disk default of type local, from mark 0 with max_rows_to_read = 2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::ErrnoException::ErrnoException(String&&, int, int) @ 0x00000000246e5d9f 4. ./contrib/llvm-project/libcxx/include/string:1499: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x00000000246e5b89 5. ./build_docker/./src/IO/OpenedFile.cpp:33: DB::OpenedFile::open() const @ 0x000000002e901613 6. ./build_docker/./src/IO/OpenedFile.cpp:42: DB::OpenedFile::getFD() const @ 0x000000002e90166d 7. ./src/IO/AsynchronousReadBufferFromFile.h:75: DB::AsynchronousReadBufferFromFileWithDescriptorsCache::AsynchronousReadBufferFromFileWithDescriptorsCache(DB::IAsynchronousReader&, Priority, String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000002e8f93fd 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&>(DB::IOUringReader&, Priority const&, String const&, unsigned long&, int&, char*&, unsigned long&, std::optional&, std::shared_ptr const&) @ 0x000000002e8f5f9c 9. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:111: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x000000002e8f5199 10. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:220: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x000000002e8f4df0 11. ./build_docker/./src/Disks/DiskLocal.cpp:335: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000002f9b546f 12. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:131: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000003297d74e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:76: std::unique_ptr> std::__function::__policy_invoker> ()>::__call_impl> ()>>(std::__function::__policy_storage const*) @ 0x0000000032dc676e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000032dbab6f 15. ./src/Compression/CachedCompressedReadBuffer.h:65: DB::CachedCompressedReadBuffer::setReadUntilPosition(unsigned long) @ 0x0000000032dbe2f2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:37: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000032db8022 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:111: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000032de7c54 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:183: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000032de7dcd 19. ./src/Storages/MergeTree/MergeTreeRangeReader.h:135: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000032df81f7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df4bbe 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:164: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000032e04f6f 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000033f8b134 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:139: DB::MergeTreeSelectProcessor::read() @ 0x0000000032de396f 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:0: DB::MergeTreeSource::tryGenerate() @ 0x0000000033fb1d35 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 30. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 31. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 2025.03.05 21:11:41.709482 [ 1017 ] {} test_rty5xhw6.rmt1 (ReplicatedMergeTreePartCheckThread): ReplicatedCheckResult DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(const String &, bool): Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/store/3b7/3b7524a2-72f7-4e5f-80a3-366020504bac/all_0_1_1/columns.txt: , errno: 2, strerror: No such file or directory. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::ErrnoException::ErrnoException(String&&, int, int) @ 0x00000000246e5d9f 4. ./contrib/llvm-project/libcxx/include/string:1499: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x00000000246e5b89 5. ./build_docker/./src/IO/OpenedFile.cpp:33: DB::OpenedFile::open() const @ 0x000000002e901613 6. ./build_docker/./src/IO/OpenedFile.cpp:42: DB::OpenedFile::getFD() const @ 0x000000002e90166d 7. ./src/IO/ReadBufferFromFile.h:101: DB::ReadBufferFromFilePReadWithDescriptorsCache::ReadBufferFromFilePReadWithDescriptorsCache(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000002e8f655d 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&>(String const&, unsigned long&, int&, char*&, unsigned long&, std::optional&, std::shared_ptr const&) @ 0x000000002e8f5d3d 9. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:91: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x000000002e8f4f22 10. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:220: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x000000002e8f4df0 11. ./build_docker/./src/Disks/DiskLocal.cpp:335: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000002f9b546f 12. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:131: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000003297d74e 13. ./build_docker/./src/Storages/MergeTree/checkDataPart.cpp:134: DB::checkDataPart(std::shared_ptr, DB::IDataPartStorage const&, DB::NamesAndTypesList const&, DB::MergeTreeDataPartType const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::ReadSettings const&, bool, std::function, bool&, bool) @ 0x00000000330576b8 14. ./build_docker/./src/Storages/MergeTree/checkDataPart.cpp:423: DB::checkDataPart(std::shared_ptr, bool, bool&, std::function, bool) @ 0x0000000033057197 15. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(String const&, bool) @ 0x0000000032f7bba4 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:444: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x0000000032f82664 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReplicatedMergeTreePartCheckThread::run() @ 0x0000000032f87054 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f0fe371 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002f103012 20. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002f103e52 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:41.709571 [ 1017 ] {} test_rty5xhw6.rmt1 (ReplicatedMergeTreePartCheckThread): Part all_0_1_1 looks broken. Removing it and will try to fetch. 2025.03.05 21:11:41.709609 [ 1017 ] {} test_rty5xhw6.rmt1 (ReplicatedMergeTreePartCheckThread): Part all_0_1_1 exists in ZooKeeper and the local part was broken. Detaching it, removing from ZooKeeper and queueing a fetch. 2025.03.05 21:11:41.710952 [ 1017 ] {} test_rty5xhw6.rmt1 (3b7524a2-72f7-4e5f-80a3-366020504bac): Detached 3 parts covered by broken part all_0_1_1: all_0_1_1, all_0_0_0, all_1_1_0 2025.03.05 21:11:42.098406 [ 23593 ] {02366_5} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:48698) (comment: 02366_cancel_write_into_file.sh) (in query: insert into function file('02366_data_5.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:42.109073 [ 23593 ] {02366_5} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:42.131609 [ 14974 ] {02366_3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:48738) (comment: 02366_cancel_write_into_file.sh) (in query: insert into function file('02366_data_3.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:42.144113 [ 14974 ] {02366_3} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:45.493969 [ 23597 ] {a0e0e4d7-2ef6-4c00-837a-866b496f5654} executeQuery: Code: 344. DB::Exception: Experimental Inverted Index feature is not enabled (turn on setting 'allow_experimental_inverted_index'). (SUPPORT_IS_DISABLED) (version 24.3.12.76.altinitystable) (from [::1]:49336) (comment: 02346_inverted_index_experimental_flag.sql) (in query: ALTER TABLE tab ADD INDEX inv_idx(str) TYPE inverted(0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3124: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b448c2 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:45.494154 [ 23597 ] {a0e0e4d7-2ef6-4c00-837a-866b496f5654} TCPHandler: Code: 344. DB::Exception: Experimental Inverted Index feature is not enabled (turn on setting 'allow_experimental_inverted_index'). (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3124: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b448c2 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:45.668477 [ 3522 ] {02366_2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:49072) (comment: 02366_cancel_write_into_file.sh) (in query: insert into function file('02366_data_2.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:45.674651 [ 3522 ] {02366_2} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:45.739084 [ 12524 ] {02366_3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:49092) (comment: 02366_cancel_write_into_file.sh) (in query: insert into function file('02366_data_3.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:45.743582 [ 12524 ] {02366_3} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:45.847096 [ 23498 ] {451b5195-331b-4a1d-9336-ff5df81ac665} executeQuery: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalMonth' given. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:49362) (comment: 02346_non_negative_derivative.sql) (in query: -- shall not work for month, quarter, year (intervals with floating number of seconds) -- Month SELECT ts, metric, nonNegativeDerivative(metric, ts, INTERVAL 11 MONTH) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c9736b 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2498: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96748 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96082 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c95dcc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c73a08 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:11:45.847347 [ 23498 ] {451b5195-331b-4a1d-9336-ff5df81ac665} TCPHandler: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalMonth' given. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c9736b 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2498: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96748 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96082 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c95dcc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c73a08 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:11:45.847838 [ 23582 ] {02366_7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:49104) (comment: 02366_cancel_write_into_file.sh) (in query: insert into function file('02366_data_7.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:45.848217 [ 23582 ] {02366_7} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:45.850031 [ 23498 ] {7ace06a3-8f47-4743-a906-9e6d54f3c3fc} executeQuery: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalQuarter' given. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:49362) (comment: 02346_non_negative_derivative.sql) (in query: -- Quarter SELECT ts, metric, nonNegativeDerivative(metric, ts, INTERVAL 12 QUARTER) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c9736b 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2498: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96748 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96082 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c95dcc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c73a08 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:11:45.850193 [ 23498 ] {7ace06a3-8f47-4743-a906-9e6d54f3c3fc} TCPHandler: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalQuarter' given. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c9736b 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2498: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96748 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96082 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c95dcc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c73a08 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:11:45.852038 [ 23498 ] {5a1d28be-65e2-449c-992e-ad511aaaeb99} executeQuery: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalYear' given. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:49362) (comment: 02346_non_negative_derivative.sql) (in query: -- Year SELECT ts, metric, nonNegativeDerivative(metric, ts, INTERVAL 13 YEAR) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c9736b 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2498: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96748 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96082 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c95dcc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c73a08 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:11:45.852155 [ 23498 ] {5a1d28be-65e2-449c-992e-ad511aaaeb99} TCPHandler: Code: 43. DB::Exception: The INTERVAL must be a week or shorter, 'IntervalYear' given. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c9736b 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2498: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96748 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96082 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c95dcc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c73a08 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:11:45.885662 [ 23498 ] {890d1f74-50b8-41e5-9572-4a2de7fe01b0} executeQuery: Code: 36. DB::Exception: Argument 1 must be DateTime or DateTime64, 'UInt8' given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49362) (comment: 02346_non_negative_derivative.sql) (in query: -- test against wrong arguments/types SELECT ts, metric, nonNegativeDerivative(metric, 1, INTERVAL 3 NANOSECOND) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001b866453 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96ed3 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2498: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96748 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96082 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c95dcc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c73a08 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:11:45.885895 [ 23498 ] {890d1f74-50b8-41e5-9572-4a2de7fe01b0} TCPHandler: Code: 36. DB::Exception: Argument 1 must be DateTime or DateTime64, 'UInt8' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001b866453 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96ed3 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2498: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96748 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96082 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c95dcc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c73a08 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:11:45.920469 [ 23498 ] {410db902-b042-4882-b772-2264750c9cb1} executeQuery: Code: 36. DB::Exception: Argument 0 must be a number, 'String' given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49362) (comment: 02346_non_negative_derivative.sql) (in query: SELECT ts, metric, nonNegativeDerivative('string not datetime', ts, INTERVAL 3 NANOSECOND) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001b866453 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96dae 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2498: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96748 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96082 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c95dcc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c73a08 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:11:45.920503 [ 23590 ] {02366_4} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:49166) (comment: 02366_cancel_write_into_file.sh) (in query: insert into function file('02366_data_4.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:45.920755 [ 23498 ] {410db902-b042-4882-b772-2264750c9cb1} TCPHandler: Code: 36. DB::Exception: Argument 0 must be a number, 'String' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001b866453 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96dae 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2498: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96748 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96082 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c95dcc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c73a08 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:11:45.921044 [ 23590 ] {02366_4} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:45.955526 [ 23498 ] {69b76317-631e-4e77-84a5-49a7d6e21f17} executeQuery: Code: 36. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49362) (comment: 02346_non_negative_derivative.sql) (in query: SELECT ts, metric, nonNegativeDerivative(metric, ts, INTERVAL 3 NANOSECOND, id) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96c74 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2498: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96748 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96082 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c95dcc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c73a08 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:11:45.955779 [ 23498 ] {69b76317-631e-4e77-84a5-49a7d6e21f17} TCPHandler: Code: 36. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96c74 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2498: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96748 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96082 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c95dcc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c73a08 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:11:45.958261 [ 23498 ] {888e9e97-c8cd-4126-8411-3362e29d99e8} executeQuery: Code: 36. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49362) (comment: 02346_non_negative_derivative.sql) (in query: SELECT ts, metric, nonNegativeDerivative(metric) OVER (PARTITION BY metric ORDER BY ts, metric ASC Rows BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING) AS deriv FROM nnd;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96c74 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2498: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96748 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96082 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c95dcc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c73a08 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:11:45.958388 [ 23498 ] {888e9e97-c8cd-4126-8411-3362e29d99e8} TCPHandler: Code: 36. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::NonNegativeDerivativeParams::NonNegativeDerivativeParams(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96c74 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2498: DB::WindowFunctionNonNegativeDerivative::WindowFunctionNonNegativeDerivative(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96748 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c96082 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c95dcc 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c73a08 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:11:46.199514 [ 23628 ] {0baefc9d-5bb1-41d1-9b13-c328eb49287b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.n, 3333_UInt16) :: 0) -> throwIf(equals(__table1.n, 3333_UInt16)) UInt8 : 1': while pushing to view test_jupdleut.landing_to_target (ae5a607a-9360-4652-a30d-9d703804c39b). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:49418) (comment: 02345_implicit_transaction.sql) (in query: INSERT INTO landing SELECT * FROM numbers(10000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 16. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 18. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:753: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000033ca5936 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52c06 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51924 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 26. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 27. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.199886 [ 23628 ] {0baefc9d-5bb1-41d1-9b13-c328eb49287b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.n, 3333_UInt16) :: 0) -> throwIf(equals(__table1.n, 3333_UInt16)) UInt8 : 1': while pushing to view test_jupdleut.landing_to_target (ae5a607a-9360-4652-a30d-9d703804c39b). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 16. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 18. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:753: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000033ca5936 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52c06 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51924 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 26. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 27. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.243099 [ 23628 ] {c68f43ac-8c1f-4301-b0d4-e86b1be864ae} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.n, 3333_UInt16) :: 0) -> throwIf(equals(__table1.n, 3333_UInt16)) UInt8 : 1': while pushing to view test_jupdleut.landing_to_target (ae5a607a-9360-4652-a30d-9d703804c39b). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:49418) (comment: 02345_implicit_transaction.sql) (in query: INSERT INTO landing SELECT * FROM numbers(10000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 16. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 18. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:753: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000033ca5936 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52c06 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51924 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 26. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 27. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.243382 [ 23628 ] {c68f43ac-8c1f-4301-b0d4-e86b1be864ae} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.n, 3333_UInt16) :: 0) -> throwIf(equals(__table1.n, 3333_UInt16)) UInt8 : 1': while pushing to view test_jupdleut.landing_to_target (ae5a607a-9360-4652-a30d-9d703804c39b). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 16. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 18. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:753: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000033ca5936 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52c06 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51924 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 26. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 27. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.270995 [ 23628 ] {a4a1f1bc-13d5-4694-94dd-c143fc56c52f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.n, 3333_UInt16) :: 0) -> throwIf(equals(__table1.n, 3333_UInt16)) UInt8 : 1': while pushing to view test_jupdleut.landing_to_target (ae5a607a-9360-4652-a30d-9d703804c39b). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:49418) (comment: 02345_implicit_transaction.sql) (in query: -- Same but using implicit_transaction INSERT INTO landing SETTINGS implicit_transaction=True SELECT * FROM numbers(10000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 16. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 18. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:753: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000033ca5936 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52c06 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51924 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 26. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 27. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.271380 [ 23628 ] {a4a1f1bc-13d5-4694-94dd-c143fc56c52f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.n, 3333_UInt16) :: 0) -> throwIf(equals(__table1.n, 3333_UInt16)) UInt8 : 1': while pushing to view test_jupdleut.landing_to_target (ae5a607a-9360-4652-a30d-9d703804c39b). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 16. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 18. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:753: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000033ca5936 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52c06 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51924 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 26. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 27. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.300286 [ 23628 ] {e466ad02-c23b-4104-b9a7-23887519ad6b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.n, 3333_UInt16) :: 0) -> throwIf(equals(__table1.n, 3333_UInt16)) UInt8 : 1': while pushing to view test_jupdleut.landing_to_target (ae5a607a-9360-4652-a30d-9d703804c39b). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:49418) (comment: 02345_implicit_transaction.sql) (in query: INSERT INTO landing SELECT * FROM numbers(10000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 16. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 18. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:753: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000033ca5936 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52c06 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51924 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 26. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 27. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.300760 [ 23628 ] {e466ad02-c23b-4104-b9a7-23887519ad6b} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.n, 3333_UInt16) :: 0) -> throwIf(equals(__table1.n, 3333_UInt16)) UInt8 : 1': while pushing to view test_jupdleut.landing_to_target (ae5a607a-9360-4652-a30d-9d703804c39b). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 16. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 18. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:753: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000033ca5936 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52c06 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51924 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 26. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 27. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.331216 [ 23628 ] {2c989fcf-e2fa-407a-863b-8df0b4840045} executeQuery: Code: 48. DB::Exception: Storage SystemSettings (table system.settings (b41af4d4-1f9e-4c76-840a-22f87534debd)) does not support transactions. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:49418) (comment: 02345_implicit_transaction.sql) (in query: -- Reading from incompatible sources with implicit_transaction works the same way as with normal transactions: -- Currently reading from system tables inside a transaction is Not implemented: SELECT name, value, changed FROM system.settings where name = 'implicit_transaction' SETTINGS implicit_transaction=True;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100e642 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.331397 [ 23628 ] {2c989fcf-e2fa-407a-863b-8df0b4840045} TCPHandler: Code: 48. DB::Exception: Storage SystemSettings (table system.settings (b41af4d4-1f9e-4c76-840a-22f87534debd)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100e642 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.336176 [ 23628 ] {5b10b7ac-3501-433b-84fa-c96597ada8c2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:49418) (comment: 02345_implicit_transaction.sql) (in query: SELECT throwIf(number == 0) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.336274 [ 23628 ] {5b10b7ac-3501-433b-84fa-c96597ada8c2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.339688 [ 23628 ] {d20340ee-460b-4e6a-a9b4-d08d07f630e3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:49418) (comment: 02345_implicit_transaction.sql) (in query: SELECT throwIf(number == 0) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.339766 [ 23628 ] {d20340ee-460b-4e6a-a9b4-d08d07f630e3} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.342966 [ 23628 ] {a1371c66-1fb9-4f39-bf23-ec91a5cb0009} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:49418) (comment: 02345_implicit_transaction.sql) (in query: SELECT throwIf(number == 0) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.343039 [ 23628 ] {a1371c66-1fb9-4f39-bf23-ec91a5cb0009} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.346447 [ 23628 ] {6137bc05-5165-420f-a545-902c1666c71d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:49418) (comment: 02345_implicit_transaction.sql) (in query: SELECT throwIf(number == 0) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.346583 [ 23628 ] {6137bc05-5165-420f-a545-902c1666c71d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.356297 [ 23628 ] {81d8be0c-351b-4738-8efe-834f6e6d2fc9} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:49418) (comment: 02345_implicit_transaction.sql) (in query: SELECT throwIf(number == 0) FROM numbers(100) SETTINGS implicit_transaction=True;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.356393 [ 23628 ] {81d8be0c-351b-4738-8efe-834f6e6d2fc9} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.589695 [ 23553 ] {14e00846-ae35-439a-ac49-fd0d654cc85c} executeQuery: Code: 1. DB::Exception: Lambda as function argument resolved as list node with size 2. Expected 1. In scope x -> compound_value.*. (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:49458) (comment: 02343_analyzer_lambdas.sql) (in query: WITH cast(tuple(1, 1), 'Tuple (value_1 UInt64, value_2 UInt64)') AS compound_value SELECT arrayMap(x -> compound_value.*, [1,2,3]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b3c31 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.589946 [ 23553 ] {14e00846-ae35-439a-ac49-fd0d654cc85c} TCPHandler: Code: 1. DB::Exception: Lambda as function argument resolved as list node with size 2. Expected 1. In scope x -> compound_value.*. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b3c31 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.627451 [ 23553 ] {eb63a355-c65f-4917-8d1c-4da1c21e3eb8} executeQuery: Code: 1. DB::Exception: APPLY transformer APPLY x -> compound_value.* resolved as list node with size 2. Expected 1. In scope WITH CAST((1, 1), 'Tuple (value_1 UInt64, value_2 UInt64)') AS compound_value SELECT id, test_table.* APPLY (x -> compound_value.*) FROM test_table. (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:49458) (comment: 02343_analyzer_lambdas.sql) (in query: WITH cast(tuple(1, 1), 'Tuple (value_1 UInt64, value_2 UInt64)') AS compound_value SELECT id, test_table.* APPLY x -> compound_value.* FROM test_table;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long&, String&&) @ 0x000000003092dcb6 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308efa3d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882ced 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.627796 [ 23553 ] {eb63a355-c65f-4917-8d1c-4da1c21e3eb8} TCPHandler: Code: 1. DB::Exception: APPLY transformer APPLY x -> compound_value.* resolved as list node with size 2. Expected 1. In scope WITH CAST((1, 1), 'Tuple (value_1 UInt64, value_2 UInt64)') AS compound_value SELECT id, test_table.* APPLY (x -> compound_value.*) FROM test_table. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long&, String&&) @ 0x000000003092dcb6 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308efa3d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882ced 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.717801 [ 23498 ] {e9355fd8-bb7d-4317-9c7a-5172936291d7} executeQuery: Code: 174. DB::Exception: Cyclic aliases for identifier 'b'. In scope SELECT a AS b, b AS a. (CYCLIC_ALIASES) (version 24.3.12.76.altinitystable) (from [::1]:49468) (comment: 02341_analyzer_aliases_basics.sql) (in query: SELECT a AS b, b AS a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x00000000308a0511 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f537 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.739660 [ 23553 ] {a0b4dd87-5e35-48e1-b368-b73cfd0c4feb} executeQuery: Code: 36. DB::Exception: Lambda x -> (x + 1) is not allowed in expression context. In scope WITH (x, y) -> y AS lambda SELECT arrayMap(x -> (x + 1), [1, 2, 3]), (x -> (x + 1)), 1 AS x. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49458) (comment: 02343_analyzer_lambdas.sql) (in query: -- lambda(tuple(x), x + 1) parsed as lambda definion but not as call of lambda defined in WITH WITH (x, y) -> y AS lambda SELECT arrayMap(lambda(tuple(x), x + 1), [1, 2, 3]), lambda(tuple(x), x + 1), 1 AS x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884eae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 7. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.739692 [ 23498 ] {e9355fd8-bb7d-4317-9c7a-5172936291d7} TCPHandler: Code: 174. DB::Exception: Cyclic aliases for identifier 'b'. In scope SELECT a AS b, b AS a. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x00000000308a0511 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f537 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.739867 [ 23553 ] {a0b4dd87-5e35-48e1-b368-b73cfd0c4feb} TCPHandler: Code: 36. DB::Exception: Lambda x -> (x + 1) is not allowed in expression context. In scope WITH (x, y) -> y AS lambda SELECT arrayMap(x -> (x + 1), [1, 2, 3]), (x -> (x + 1)), 1 AS x. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884eae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 7. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.819489 [ 23498 ] {ec146e1b-cdd9-44ad-9a69-2edb5ba7fb68} executeQuery: Code: 174. DB::Exception: Cyclic aliases for identifier 'id'. In scope SELECT id + b AS id, id AS b FROM test_table. (CYCLIC_ALIASES) (version 24.3.12.76.altinitystable) (from [::1]:49468) (comment: 02341_analyzer_aliases_basics.sql) (in query: SELECT (id + b) AS id, id as b FROM test_table;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x00000000308a0511 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f537 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.819743 [ 23498 ] {ec146e1b-cdd9-44ad-9a69-2edb5ba7fb68} TCPHandler: Code: 174. DB::Exception: Cyclic aliases for identifier 'id'. In scope SELECT id + b AS id, id AS b FROM test_table. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x00000000308a0511 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f537 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.854340 [ 23498 ] {342c500d-ab8a-48c2-91d6-1e0b3b7dc5be} executeQuery: Code: 174. DB::Exception: Cyclic aliases for identifier 'id'. In scope SELECT ((1 + b) + 1) + id AS id, b AS c, id AS b FROM test_table. (CYCLIC_ALIASES) (version 24.3.12.76.altinitystable) (from [::1]:49468) (comment: 02341_analyzer_aliases_basics.sql) (in query: SELECT (1 + b + 1 + id) AS id, b as c, id as b FROM test_table;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x00000000308a0511 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f537 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:11:46.874706 [ 23628 ] {d99bd9a1-f37e-48cb-8d93-a82480ad9b91} executeQuery: Code: 48. DB::Exception: Storage StorageDummy (table _table_function.cluster) does not support transactions. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:49418) (comment: 02345_implicit_transaction.sql) (in query: SELECT * FROM cluster('test_cluster_interserver_secret', system, one);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100e642 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 6. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000003100323f 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc67c 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 9. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.874733 [ 23498 ] {342c500d-ab8a-48c2-91d6-1e0b3b7dc5be} TCPHandler: Code: 174. DB::Exception: Cyclic aliases for identifier 'id'. In scope SELECT ((1 + b) + 1) + id AS id, b AS c, id AS b FROM test_table. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x00000000308a0511 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f537 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:11:46.874965 [ 23628 ] {d99bd9a1-f37e-48cb-8d93-a82480ad9b91} TCPHandler: Code: 48. DB::Exception: Storage StorageDummy (table _table_function.cluster) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100e642 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 6. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000003100323f 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc67c 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 9. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.878444 [ 23628 ] {dd864df5-4f9d-46fb-92ae-4fdb220ed434} executeQuery: Code: 48. DB::Exception: Storage StorageDummy (table _table_function.cluster) does not support transactions. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:49418) (comment: 02345_implicit_transaction.sql) (in query: SELECT * FROM cluster('test_cluster_two_shards', system, one);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100e642 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 6. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000003100323f 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc67c 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 9. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.878587 [ 23628 ] {dd864df5-4f9d-46fb-92ae-4fdb220ed434} TCPHandler: Code: 48. DB::Exception: Storage StorageDummy (table _table_function.cluster) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100e642 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 6. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000003100323f 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc67c 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 9. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.901428 [ 22860 ] {41a2475b-8d23-45ea-bd98-d89bee650c34} executeQuery: Code: 649. DB::Exception: Transaction Control Language queries are allowed only inside session: while starting a transaction with 'implicit_transaction'. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::1]:49418) (comment: 02345_implicit_transaction.sql) (in query: SELECT `__table1`.`dummy` AS `dummy` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:20: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317178de 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*)::$_0::operator()(std::shared_ptr const&, DB::ASTTransactionControl::QueryType) const @ 0x000000003170c3a2 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1133: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fbf8b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.901446 [ 23553 ] {f4bc8261-3130-4e55-a079-cbdd0a3729d2} executeQuery: Code: 649. DB::Exception: Transaction Control Language queries are allowed only inside session: while starting a transaction with 'implicit_transaction'. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::1]:49418) (comment: 02345_implicit_transaction.sql) (in query: SELECT `__table1`.`dummy` AS `dummy` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:20: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317178de 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*)::$_0::operator()(std::shared_ptr const&, DB::ASTTransactionControl::QueryType) const @ 0x000000003170c3a2 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1133: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fbf8b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.901656 [ 23553 ] {f4bc8261-3130-4e55-a079-cbdd0a3729d2} TCPHandler: Code: 649. DB::Exception: Transaction Control Language queries are allowed only inside session: while starting a transaction with 'implicit_transaction'. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:20: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317178de 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*)::$_0::operator()(std::shared_ptr const&, DB::ASTTransactionControl::QueryType) const @ 0x000000003170c3a2 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1133: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fbf8b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.901942 [ 22860 ] {41a2475b-8d23-45ea-bd98-d89bee650c34} TCPHandler: Code: 649. DB::Exception: Transaction Control Language queries are allowed only inside session: while starting a transaction with 'implicit_transaction'. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:20: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317178de 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*)::$_0::operator()(std::shared_ptr const&, DB::ASTTransactionControl::QueryType) const @ 0x000000003170c3a2 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1133: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fbf8b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:46.902936 [ 23628 ] {a0a73542-342b-4116-8de0-eca01681cade} executeQuery: Code: 649. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Transaction Control Language queries are allowed only inside session: while starting a transaction with 'implicit_transaction'. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:20: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317178de 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*)::$_0::operator()(std::shared_ptr const&, DB::ASTTransactionControl::QueryType) const @ 0x000000003170c3a2 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1133: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fbf8b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 : While executing Remote. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::1]:49418) (comment: 02345_implicit_transaction.sql) (in query: -- there's not session in the interserver mode SELECT * FROM cluster('test_cluster_interserver_secret', system, one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:11:46.903313 [ 23628 ] {a0a73542-342b-4116-8de0-eca01681cade} TCPHandler: Code: 649. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Transaction Control Language queries are allowed only inside session: while starting a transaction with 'implicit_transaction'. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:20: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317178de 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*)::$_0::operator()(std::shared_ptr const&, DB::ASTTransactionControl::QueryType) const @ 0x000000003170c3a2 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1133: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fbf8b 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 : While executing Remote. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:11:47.147918 [ 23498 ] {048b5233-96d8-475a-a8e5-4e4bbfaa97f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 2, should be 1: In scope SELECT base58Encode('Hold my beer...', 'Second arg'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:49488) (comment: 02337_base58.sql) (in query: SELECT base58Encode('Hold my beer...', 'Second arg');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:47.148056 [ 23498 ] {048b5233-96d8-475a-a8e5-4e4bbfaa97f6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 2, should be 1: In scope SELECT base58Encode('Hold my beer...', 'Second arg'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:47.176032 [ 23498 ] {02dc5678-f9cf-4f11-889b-5c633c78fe19} executeQuery: Code: 36. DB::Exception: Invalid Base58 value, cannot be decoded: In scope SELECT base58Decode('Hold my beer...'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49488) (comment: 02337_base58.sql) (in query: SELECT base58Decode('Hold my beer...');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionBase58Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000198437ce 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:11:47.176306 [ 23498 ] {02dc5678-f9cf-4f11-889b-5c633c78fe19} TCPHandler: Code: 36. DB::Exception: Invalid Base58 value, cannot be decoded: In scope SELECT base58Decode('Hold my beer...'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionBase58Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000198437ce 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:11:47.813907 [ 23600 ] {66f0b70f-1da6-4e00-94a0-25978002c098} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 1, should be 2 or 3: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.23', 2, 'UTC')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:49612) (comment: 02319_timeslots_dt64.sql) (in query: SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.23', 2, 'UTC'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000001806a053 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x00000000219dc99c 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:47.838947 [ 23600 ] {66f0b70f-1da6-4e00-94a0-25978002c098} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 1, should be 2 or 3: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.23', 2, 'UTC')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000001806a053 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x00000000219dc99c 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:47.838954 [ 22866 ] {40d145bc-0a36-4e0f-b7ae-0eaf5e7697e2} executeQuery: Code: 80. DB::Exception: The maximum rows per postings list must be no less than 8192. (INCORRECT_QUERY) (version 24.3.12.76.altinitystable) (from [::1]:49374) (comment: 02346_inverted_index_search.sql) (in query: CREATE TABLE tab (`k` UInt64, `s` String, INDEX af s TYPE inverted(3, 123) GRANULARITY 1) ENGINE = MergeTree ORDER BY k SETTINGS index_granularity = 7632, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 186202728, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 15437226, merge_max_block_size = 5420, old_parts_lifetime = 30., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 34, min_merge_bytes_to_use_direct_io = 3036943144, index_granularity_bytes = 27570227, concurrent_part_removal_threshold = 45, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 40011, primary_key_compress_block_size = 87766 AS SELECT number, format('{},{},{},{}', hex(12345678), hex(87654321), hex((number / 17) + 5), hex(13579012)) AS s FROM numbers(1024)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x00000000192fbcfb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexInverted.cpp:819: DB::invertedIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000032cc159f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af08f7 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 10. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 12. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:47.839225 [ 22866 ] {40d145bc-0a36-4e0f-b7ae-0eaf5e7697e2} TCPHandler: Code: 80. DB::Exception: The maximum rows per postings list must be no less than 8192. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x00000000192fbcfb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexInverted.cpp:819: DB::invertedIndexValidator(DB::IndexDescription const&, bool) @ 0x0000000032cc159f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af08f7 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 10. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 12. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:47.841279 [ 23600 ] {7c16d07a-89dd-4e1c-a36e-3248eefd2d74} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 4, should be 2 or 3: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.345', 3, 'UTC'), toDecimal64(62.3, 1), toDecimal64(12.34, 2), 'one more'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:49612) (comment: 02319_timeslots_dt64.sql) (in query: SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.345', 3, 'UTC'), toDecimal64(62.3, 1), toDecimal64(12.34, 2), 'one more');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000001806a053 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x00000000219dc99c 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:47.841412 [ 23600 ] {7c16d07a-89dd-4e1c-a36e-3248eefd2d74} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 4, should be 2 or 3: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.345', 3, 'UTC'), toDecimal64(62.3, 1), toDecimal64(12.34, 2), 'one more'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000001806a053 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x00000000219dc99c 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:47.865372 [ 23600 ] {b114bb6e-5da9-44ee-8d5e-1516528816c5} executeQuery: Code: 43. DB::Exception: Illegal type String of second argument of function timeSlots. Must be Decimal64 when first argument is DateTime64.: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.456', 3, 'UTC'), 'wrong argument'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:49612) (comment: 02319_timeslots_dt64.sql) (in query: SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.456', 3, 'UTC'), 'wrong argument');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x00000000219dd17c 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:47.865579 [ 23600 ] {b114bb6e-5da9-44ee-8d5e-1516528816c5} TCPHandler: Code: 43. DB::Exception: Illegal type String of second argument of function timeSlots. Must be Decimal64 when first argument is DateTime64.: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.456', 3, 'UTC'), 'wrong argument'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x00000000219dd17c 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:47.891536 [ 23600 ] {4fde25ae-316f-4aeb-b8a7-553ccc69e905} executeQuery: Code: 43. DB::Exception: Illegal type String of third argument of function timeSlots. Must be Decimal64 when first argument is DateTime64.: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.123', 3, 'UTC'), toDecimal64(600, 0), 'wrong argument'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:49612) (comment: 02319_timeslots_dt64.sql) (in query: SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.123', 3, 'UTC'), toDecimal64(600, 0), 'wrong argument');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x00000000219dd448 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:47.891728 [ 23600 ] {4fde25ae-316f-4aeb-b8a7-553ccc69e905} TCPHandler: Code: 43. DB::Exception: Illegal type String of third argument of function timeSlots. Must be Decimal64 when first argument is DateTime64.: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.123', 3, 'UTC'), toDecimal64(600, 0), 'wrong argument'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x00000000219dd448 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:47.921551 [ 23600 ] {f36f61a1-3b23-4d91-a853-083ff6eb58ea} executeQuery: Code: 44. DB::Exception: Third argument for function timeSlots must be greater than zero: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.1232', 4, 'UTC'), toDecimal64(600, 0), toDecimal64(0, 0)). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:49612) (comment: 02319_timeslots_dt64.sql) (in query: SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.1232', 4, 'UTC'), toDecimal64(600, 0), toDecimal64(0, 0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionTimeSlots::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219dac48 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:11:47.921732 [ 23600 ] {f36f61a1-3b23-4d91-a853-083ff6eb58ea} TCPHandler: Code: 44. DB::Exception: Third argument for function timeSlots must be greater than zero: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.1232', 4, 'UTC'), toDecimal64(600, 0), toDecimal64(0, 0)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionTimeSlots::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219dac48 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:11:48.082740 [ 23553 ] {c103ade4-2863-413f-a046-44d82f629d5a} executeQuery: Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/format_schemas/nonexist: , errno: 2, strerror: No such file or directory: The table structure cannot be extracted from a Template format file. You can specify the structure manually. (FILE_DOESNT_EXIST) (version 24.3.12.76.altinitystable) (from [::1]:49640) (comment: 02318_template_schema_inference_bug.sql) (in query: desc file('data_02318.tsv', 'Template') SETTINGS format_template_row='nonexist', format_template_resultset='nonexist';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::ErrnoException::ErrnoException(String&&, int, int) @ 0x00000000246e5d9f 4. ./contrib/llvm-project/libcxx/include/string:1499: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&) @ 0x00000000246fabc9 5. ./build_docker/./src/IO/ReadBufferFromFile.cpp:48: DB::ReadBufferFromFile::ReadBufferFromFile(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x00000000246ffa8a 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ParsedTemplateFormatString::ParsedTemplateFormatString(DB::FormatSchemaInfo const&, std::function (String const&)> const&, bool) @ 0x0000000033ac7633 7. ./build_docker/./src/Processors/Formats/Impl/TemplateRowInputFormat.cpp:0: DB::fillRowFormat(DB::FormatSettings const&, std::function (String const&)>, bool) @ 0x0000000033ad40f0 8. ./build_docker/./src/Processors/Formats/Impl/TemplateRowInputFormat.cpp:0: String std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*, DB::FormatSettings const&) @ 0x0000000033ad46b6 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000334f02ce 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::getKeysForSchemaCache(std::vector> const&, String const&, std::optional const&, std::shared_ptr const&) @ 0x0000000033519c85 11. ./contrib/llvm-project/libcxx/include/vector:556: DB::getKeyForSchemaCache(String const&, String const&, std::optional const&, std::shared_ptr const&) @ 0x0000000033519b44 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:781: ? @ 0x0000000032203c2a 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::(anonymous namespace)::ReadBufferFromFileIterator::next() @ 0x00000000322011d8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033512ef7 15. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 16. ./build_docker/./src/Storages/StorageFile.cpp:943: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321dd621 17. ./build_docker/./src/Storages/StorageFile.cpp:956: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321ddfa1 18. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4655ce 19. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 20. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:48.082961 [ 23553 ] {c103ade4-2863-413f-a046-44d82f629d5a} TCPHandler: Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/format_schemas/nonexist: , errno: 2, strerror: No such file or directory: The table structure cannot be extracted from a Template format file. You can specify the structure manually. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::ErrnoException::ErrnoException(String&&, int, int) @ 0x00000000246e5d9f 4. ./contrib/llvm-project/libcxx/include/string:1499: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&) @ 0x00000000246fabc9 5. ./build_docker/./src/IO/ReadBufferFromFile.cpp:48: DB::ReadBufferFromFile::ReadBufferFromFile(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x00000000246ffa8a 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ParsedTemplateFormatString::ParsedTemplateFormatString(DB::FormatSchemaInfo const&, std::function (String const&)> const&, bool) @ 0x0000000033ac7633 7. ./build_docker/./src/Processors/Formats/Impl/TemplateRowInputFormat.cpp:0: DB::fillRowFormat(DB::FormatSettings const&, std::function (String const&)>, bool) @ 0x0000000033ad40f0 8. ./build_docker/./src/Processors/Formats/Impl/TemplateRowInputFormat.cpp:0: String std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*, DB::FormatSettings const&) @ 0x0000000033ad46b6 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000334f02ce 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::getKeysForSchemaCache(std::vector> const&, String const&, std::optional const&, std::shared_ptr const&) @ 0x0000000033519c85 11. ./contrib/llvm-project/libcxx/include/vector:556: DB::getKeyForSchemaCache(String const&, String const&, std::optional const&, std::shared_ptr const&) @ 0x0000000033519b44 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:781: ? @ 0x0000000032203c2a 13. ./contrib/llvm-project/libcxx/include/optional:344: DB::(anonymous namespace)::ReadBufferFromFileIterator::next() @ 0x00000000322011d8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033512ef7 15. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 16. ./build_docker/./src/Storages/StorageFile.cpp:943: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321dd621 17. ./build_docker/./src/Storages/StorageFile.cpp:956: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321ddfa1 18. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4655ce 19. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 20. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:48.116726 [ 23610 ] {34c37eef-c759-499c-976b-347f33209491} executeQuery: Code: 25. DB::Exception: Invalid escape sequence at the end of LIKE pattern 'pattern\': while executing 'FUNCTION like(__table1.haystack :: 2, 'pattern\\'_String :: 1) -> like(__table1.haystack, 'pattern\\'_String) UInt8 : 0'. (CANNOT_PARSE_ESCAPE_SEQUENCE) (version 24.3.12.76.altinitystable) (from [::1]:49664) (comment: 02317_like_with_trailing_escape.sql) (in query: -- const pattern SELECT haystack LIKE 'pattern\\' from tab;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001cea75fb 4. ./build_docker/./src/Common/likePatternToRegexp.cpp:61: DB::likePatternToRegexp(std::basic_string_view>) @ 0x00000000246f5c31 5. DB::MatchImpl::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001e9c5e2f 6. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e9c2cad 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:48.116933 [ 23610 ] {34c37eef-c759-499c-976b-347f33209491} TCPHandler: Code: 25. DB::Exception: Invalid escape sequence at the end of LIKE pattern 'pattern\': while executing 'FUNCTION like(__table1.haystack :: 2, 'pattern\\'_String :: 1) -> like(__table1.haystack, 'pattern\\'_String) UInt8 : 0'. (CANNOT_PARSE_ESCAPE_SEQUENCE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001cea75fb 4. ./build_docker/./src/Common/likePatternToRegexp.cpp:61: DB::likePatternToRegexp(std::basic_string_view>) @ 0x00000000246f5c31 5. DB::MatchImpl::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001e9c5e2f 6. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e9c2cad 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:48.148522 [ 23610 ] {7f99a224-75cc-4efa-8a08-86cbebc252ca} executeQuery: Code: 25. DB::Exception: Invalid escape sequence at the end of LIKE pattern 'pattern\': while executing 'FUNCTION like(__table1.haystack :: 2, __table1.pattern :: 0) -> like(__table1.haystack, __table1.pattern) UInt8 : 1'. (CANNOT_PARSE_ESCAPE_SEQUENCE) (version 24.3.12.76.altinitystable) (from [::1]:49664) (comment: 02317_like_with_trailing_escape.sql) (in query: -- non-const pattern SELECT haystack LIKE pattern from tab;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001cea75fb 4. ./build_docker/./src/Common/likePatternToRegexp.cpp:61: DB::likePatternToRegexp(std::basic_string_view>) @ 0x00000000246f5c31 5. OptimizedRegularExpression DB::Regexps::createRegexp(String const&) @ 0x000000001e9c9eec 6. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x000000001e9c930e 7. DB::MatchImpl::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001e9c4d10 8. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e9c2af9 9. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 23. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:48.148734 [ 23610 ] {7f99a224-75cc-4efa-8a08-86cbebc252ca} TCPHandler: Code: 25. DB::Exception: Invalid escape sequence at the end of LIKE pattern 'pattern\': while executing 'FUNCTION like(__table1.haystack :: 2, __table1.pattern :: 0) -> like(__table1.haystack, __table1.pattern) UInt8 : 1'. (CANNOT_PARSE_ESCAPE_SEQUENCE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001cea75fb 4. ./build_docker/./src/Common/likePatternToRegexp.cpp:61: DB::likePatternToRegexp(std::basic_string_view>) @ 0x00000000246f5c31 5. OptimizedRegularExpression DB::Regexps::createRegexp(String const&) @ 0x000000001e9c9eec 6. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x000000001e9c930e 7. DB::MatchImpl::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001e9c4d10 8. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e9c2af9 9. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 23. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:48.650128 [ 23600 ] {183052dc-8ec8-4797-a8cb-325f860d3401} executeQuery: Code: 36. DB::Exception: DELETE query is not supported for table test_k1hclvvi.t_proj. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49654) (comment: 02319_lightweight_delete_on_merge_tree.sql) (in query: DELETE FROM t_proj WHERE a < 100;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:0: DB::InterpreterDeleteQuery::execute() @ 0x00000000317d6b27 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:48.650344 [ 23600 ] {183052dc-8ec8-4797-a8cb-325f860d3401} TCPHandler: Code: 36. DB::Exception: DELETE query is not supported for table test_k1hclvvi.t_proj. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:0: DB::InterpreterDeleteQuery::execute() @ 0x00000000317d6b27 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:48.703284 [ 23600 ] {436fe036-9d2d-455c-9214-48d0d64b464f} executeQuery: Code: 344. DB::Exception: Lightweight delete mutate is disabled. Set `enable_lightweight_delete` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.3.12.76.altinitystable) (from [::1]:49654) (comment: 02319_lightweight_delete_on_merge_tree.sql) (in query: DELETE FROM merge_table_standard_delete WHERE id = 10;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:83: DB::InterpreterDeleteQuery::execute() @ 0x00000000317d6c31 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:48.703475 [ 23600 ] {436fe036-9d2d-455c-9214-48d0d64b464f} TCPHandler: Code: 344. DB::Exception: Lightweight delete mutate is disabled. Set `enable_lightweight_delete` setting to enable it. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:83: DB::InterpreterDeleteQuery::execute() @ 0x00000000317d6c31 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:48.707040 [ 23600 ] {80e23ee9-b94e-4ddc-8cc3-7c6bc6619db3} executeQuery: Code: 344. DB::Exception: Lightweight delete mutate is disabled. Set `enable_lightweight_delete` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.3.12.76.altinitystable) (from [::1]:49654) (comment: 02319_lightweight_delete_on_merge_tree.sql) (in query: DELETE FROM merge_table_standard_delete WHERE id = 10;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:83: DB::InterpreterDeleteQuery::execute() @ 0x00000000317d6c31 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:48.707178 [ 23600 ] {80e23ee9-b94e-4ddc-8cc3-7c6bc6619db3} TCPHandler: Code: 344. DB::Exception: Lightweight delete mutate is disabled. Set `enable_lightweight_delete` setting to enable it. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:83: DB::InterpreterDeleteQuery::execute() @ 0x00000000317d6c31 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:49.225604 [ 23593 ] {0bb79902-1cbd-4864-8057-99861447de15} executeQuery: Code: 48. DB::Exception: GROUPING SETS are not supported together with ROLLUP and CUBE. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:33100) (comment: 02304_grouping_sets_with_rollup_cube.sql) (in query: SELECT number FROM numbers(10) GROUP BY GROUPING SETS ( number, number % 2 ) WITH ROLLUP;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8031: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030877ebd 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:49.225830 [ 23593 ] {0bb79902-1cbd-4864-8057-99861447de15} TCPHandler: Code: 48. DB::Exception: GROUPING SETS are not supported together with ROLLUP and CUBE. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8031: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030877ebd 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:49.227694 [ 23593 ] {483677ba-53ec-4482-9f6c-9c4e52322bb9} executeQuery: Code: 48. DB::Exception: GROUPING SETS are not supported together with ROLLUP and CUBE. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:33100) (comment: 02304_grouping_sets_with_rollup_cube.sql) (in query: SELECT number FROM numbers(10) GROUP BY GROUPING SETS ( number, number % 2 ) WITH CUBE;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8031: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030877ebd 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:49.227799 [ 23593 ] {483677ba-53ec-4482-9f6c-9c4e52322bb9} TCPHandler: Code: 48. DB::Exception: GROUPING SETS are not supported together with ROLLUP and CUBE. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8031: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030877ebd 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.460471 [ 23553 ] {604c58f3-b853-42c8-a525-3034ef6145ba} executeQuery: Code: 50. DB::Exception: Unknown data type family: NULL. (UNKNOWN_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:33140) (comment: 02302_column_decl_null_before_defaul_value.sql) (in query: ALTER TABLE null_before MODIFY COLUMN id NULL DEFAULT 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:266: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x000000002f47e8b1 5. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:144: std::shared_ptr DB::DataTypeFactory::getImpl(String const&, std::shared_ptr const&) const @ 0x000000002f47c91b 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::AlterCommand::parse(DB::ASTAlterCommand const*) @ 0x00000000320734a2 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030794524 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.460739 [ 23553 ] {604c58f3-b853-42c8-a525-3034ef6145ba} TCPHandler: Code: 50. DB::Exception: Unknown data type family: NULL. (UNKNOWN_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:266: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x000000002f47e8b1 5. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:144: std::shared_ptr DB::DataTypeFactory::getImpl(String const&, std::shared_ptr const&) const @ 0x000000002f47c91b 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::AlterCommand::parse(DB::ASTAlterCommand const*) @ 0x00000000320734a2 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030794524 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.703156 [ 23610 ] {39a2ac33-896f-4e14-b6c5-9f9f7103e52f} executeQuery: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:33186) (comment: 02296_ttl_non_deterministic.sql) (in query: CREATE TABLE t_ttl_non_deterministic (`A` Int64) ENGINE = MergeTree ORDER BY A TTL now() + toIntervalMonth(1) SETTINGS index_granularity = 63336, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 307913025, compact_parts_max_granules_to_buffer = 229, compact_parts_merge_max_bytes_to_prefetch_part = 30790161, merge_max_block_size = 7259, old_parts_lifetime = 349., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 974762257, index_granularity_bytes = 30946595, concurrent_part_removal_threshold = 78, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 43520, primary_key_compress_block_size = 61479), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/TTLDescription.cpp:65: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326975a5 5. ./build_docker/./src/Storages/TTLDescription.cpp:396: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326983a8 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:587: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306b2bf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.703395 [ 23610 ] {39a2ac33-896f-4e14-b6c5-9f9f7103e52f} TCPHandler: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/TTLDescription.cpp:65: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326975a5 5. ./build_docker/./src/Storages/TTLDescription.cpp:396: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326983a8 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:587: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306b2bf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.707075 [ 23610 ] {1a61c406-e433-4fbe-bd99-efea8d4068b6} executeQuery: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:33186) (comment: 02296_ttl_non_deterministic.sql) (in query: CREATE TABLE t_ttl_non_deterministic (`A` Int64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/ttl1', '1') ORDER BY A TTL now() + toIntervalMonth(1) SETTINGS index_granularity = 63336, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 307913025, compact_parts_max_granules_to_buffer = 229, compact_parts_merge_max_bytes_to_prefetch_part = 30790161, merge_max_block_size = 7259, old_parts_lifetime = 349., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 974762257, index_granularity_bytes = 30946595, concurrent_part_removal_threshold = 78, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 43520, primary_key_compress_block_size = 61479), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/TTLDescription.cpp:65: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326975a5 5. ./build_docker/./src/Storages/TTLDescription.cpp:396: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326983a8 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:587: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306b2bf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.707218 [ 23610 ] {1a61c406-e433-4fbe-bd99-efea8d4068b6} TCPHandler: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/TTLDescription.cpp:65: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326975a5 5. ./build_docker/./src/Storages/TTLDescription.cpp:396: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326983a8 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:587: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306b2bf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.730286 [ 23610 ] {87b3faa3-6dd7-44b4-a0de-5c91f5ca6279} executeQuery: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:33186) (comment: 02296_ttl_non_deterministic.sql) (in query: ALTER TABLE t_ttl_non_deterministic MODIFY TTL now() + toIntervalMonth(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/TTLDescription.cpp:65: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326975a5 5. ./build_docker/./src/Storages/TTLDescription.cpp:396: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326983a8 6. ./build_docker/./src/Storages/AlterCommands.cpp:769: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003207bac6 7. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000032083bec 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3e11f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.730467 [ 23610 ] {87b3faa3-6dd7-44b4-a0de-5c91f5ca6279} TCPHandler: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/TTLDescription.cpp:65: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326975a5 5. ./build_docker/./src/Storages/TTLDescription.cpp:396: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326983a8 6. ./build_docker/./src/Storages/AlterCommands.cpp:769: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003207bac6 7. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000032083bec 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3e11f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.754136 [ 23610 ] {b8486989-25c2-4e34-bd22-b829be866fea} executeQuery: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:33186) (comment: 02296_ttl_non_deterministic.sql) (in query: ALTER TABLE t_ttl_non_deterministic MODIFY TTL now() + toIntervalMonth(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/TTLDescription.cpp:65: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326975a5 5. ./build_docker/./src/Storages/TTLDescription.cpp:396: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326983a8 6. ./build_docker/./src/Storages/AlterCommands.cpp:769: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003207bac6 7. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000032083bec 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3e11f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.754370 [ 23610 ] {b8486989-25c2-4e34-bd22-b829be866fea} TCPHandler: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/TTLDescription.cpp:65: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326975a5 5. ./build_docker/./src/Storages/TTLDescription.cpp:396: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326983a8 6. ./build_docker/./src/Storages/AlterCommands.cpp:769: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003207bac6 7. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000032083bec 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3e11f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.793067 [ 23610 ] {1d2f28e8-f87d-4e0b-bc90-7369ddfcc152} executeQuery: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:33186) (comment: 02296_ttl_non_deterministic.sql) (in query: CREATE TABLE t_ttl_non_deterministic (`A` Int64, `B` Int64 TTL now() + toIntervalMonth(1)) ENGINE = MergeTree ORDER BY A SETTINGS index_granularity = 63336, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 307913025, compact_parts_max_granules_to_buffer = 229, compact_parts_merge_max_bytes_to_prefetch_part = 30790161, merge_max_block_size = 7259, old_parts_lifetime = 349., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 974762257, index_granularity_bytes = 30946595, concurrent_part_removal_threshold = 78, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 43520, primary_key_compress_block_size = 61479), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/TTLDescription.cpp:65: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326975a5 5. ./contrib/llvm-project/libcxx/include/unordered_map:1805: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306bb58 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.793300 [ 23610 ] {1d2f28e8-f87d-4e0b-bc90-7369ddfcc152} TCPHandler: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/TTLDescription.cpp:65: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326975a5 5. ./contrib/llvm-project/libcxx/include/unordered_map:1805: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306bb58 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.796274 [ 23610 ] {34a66176-4162-40e4-a368-a02baf63babb} executeQuery: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:33186) (comment: 02296_ttl_non_deterministic.sql) (in query: CREATE TABLE t_ttl_non_deterministic (`A` Int64, `B` Int64 TTL now() + toIntervalMonth(1)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/ttl3', '1') ORDER BY A SETTINGS index_granularity = 63336, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 307913025, compact_parts_max_granules_to_buffer = 229, compact_parts_merge_max_bytes_to_prefetch_part = 30790161, merge_max_block_size = 7259, old_parts_lifetime = 349., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 974762257, index_granularity_bytes = 30946595, concurrent_part_removal_threshold = 78, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 43520, primary_key_compress_block_size = 61479), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/TTLDescription.cpp:65: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326975a5 5. ./contrib/llvm-project/libcxx/include/unordered_map:1805: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306bb58 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.796421 [ 23610 ] {34a66176-4162-40e4-a368-a02baf63babb} TCPHandler: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/TTLDescription.cpp:65: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326975a5 5. ./contrib/llvm-project/libcxx/include/unordered_map:1805: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306bb58 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.817602 [ 23610 ] {7e5800d2-2c66-4def-926b-fe0f6693b764} executeQuery: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:33186) (comment: 02296_ttl_non_deterministic.sql) (in query: ALTER TABLE t_ttl_non_deterministic MODIFY COLUMN B Int64 TTL now() + toIntervalMonth(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/TTLDescription.cpp:65: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326975a5 5. ./contrib/llvm-project/libcxx/include/unordered_map:1805: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000032084d60 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3e11f 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.817848 [ 23610 ] {7e5800d2-2c66-4def-926b-fe0f6693b764} TCPHandler: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/TTLDescription.cpp:65: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326975a5 5. ./contrib/llvm-project/libcxx/include/unordered_map:1805: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000032084d60 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3e11f 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.857905 [ 23610 ] {2d2f2d3c-7c53-463b-8acc-748f8a9fea49} executeQuery: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:33186) (comment: 02296_ttl_non_deterministic.sql) (in query: ALTER TABLE t_ttl_non_deterministic MODIFY COLUMN B Int64 TTL now() + toIntervalMonth(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/TTLDescription.cpp:65: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326975a5 5. ./contrib/llvm-project/libcxx/include/unordered_map:1805: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000032084d60 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3e11f 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.857897 [ 23621 ] {8fd67f04-af7b-466c-921f-e70f3b607c31} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAny: In scope SELECT multiSearchAny(materialize('Hello World'), materialize([])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:33216) (comment: 02294_stringsearch_with_nonconst_needle.sql) (in query: select multiSearchAny(materialize('Hello World'), materialize([]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionsMultiStringSearch>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001fd52601 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.858063 [ 23610 ] {2d2f2d3c-7c53-463b-8acc-748f8a9fea49} TCPHandler: Code: 36. DB::Exception: TTL expression now() + toIntervalMonth(1) does not depend on any of the columns of the table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/TTLDescription.cpp:65: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000326975a5 5. ./contrib/llvm-project/libcxx/include/unordered_map:1805: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000032084d60 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3e11f 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.858174 [ 23621 ] {8fd67f04-af7b-466c-921f-e70f3b607c31} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAny: In scope SELECT multiSearchAny(materialize('Hello World'), materialize([])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionsMultiStringSearch>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001fd52601 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.904328 [ 23621 ] {31c9dfde-0f03-43a9-99a0-25bc84189860} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstIndex: In scope SELECT multiSearchFirstIndex(materialize('Hello World'), materialize([])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:33216) (comment: 02294_stringsearch_with_nonconst_needle.sql) (in query: select multiSearchFirstIndex(materialize('Hello World'), materialize([]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionsMultiStringSearch>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001fd629c1 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.904581 [ 23621 ] {31c9dfde-0f03-43a9-99a0-25bc84189860} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstIndex: In scope SELECT multiSearchFirstIndex(materialize('Hello World'), materialize([])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionsMultiStringSearch>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001fd629c1 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.956272 [ 23621 ] {41f86589-82f7-436b-aa7c-4a8ffa121b8b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstPosition: In scope SELECT multiSearchFirstPosition(materialize('Hello World'), materialize([])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:33216) (comment: 02294_stringsearch_with_nonconst_needle.sql) (in query: select multiSearchFirstPosition(materialize('Hello World'), materialize([]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionsMultiStringSearch>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001fd730e1 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:50.956453 [ 23621 ] {41f86589-82f7-436b-aa7c-4a8ffa121b8b} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstPosition: In scope SELECT multiSearchFirstPosition(materialize('Hello World'), materialize([])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionsMultiStringSearch>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001fd730e1 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:51.156618 [ 23610 ] {fdf7b077-88ea-4f5f-a69d-c7174df0a2d3} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 8 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.3.12.76.altinitystable) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference. You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_jfutmtg3_data1.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.3.12.76.altinitystable) (from [::1]:33254) (comment: 02305_schema_inference_with_globs.sh) (in query: desc file('02305_schema_inference_with_globs_test_jfutmtg3_data*.jsonl') settings input_format_max_rows_to_read_for_schema_inference=8, input_format_json_infer_incomplete_types_as_strings=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:480: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033518072 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./build_docker/./src/Storages/StorageFile.cpp:943: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321dd621 7. ./build_docker/./src/Storages/StorageFile.cpp:956: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321ddfa1 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4655ce 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:51.157155 [ 23610 ] {fdf7b077-88ea-4f5f-a69d-c7174df0a2d3} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 8 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.3.12.76.altinitystable) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference. You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_jfutmtg3_data1.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:480: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033518072 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./build_docker/./src/Storages/StorageFile.cpp:943: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321dd621 7. ./build_docker/./src/Storages/StorageFile.cpp:956: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321ddfa1 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4655ce 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:51.367415 [ 23593 ] {92591041-8bdf-4ce2-91a2-92554544b232} executeQuery: Code: 636. DB::Exception: All attempts to extract table structure from files failed. Errors: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.3.12.76.altinitystable) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 6 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.3.12.76.altinitystable) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_jfutmtg3_data2.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.3.12.76.altinitystable) (from [::1]:33270) (comment: 02305_schema_inference_with_globs.sh) (in query: desc file('02305_schema_inference_with_globs_test_jfutmtg3_data*.jsonl') settings input_format_max_rows_to_read_for_schema_inference=16, input_format_json_infer_incomplete_types_as_strings=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033518215 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./build_docker/./src/Storages/StorageFile.cpp:943: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321dd621 7. ./build_docker/./src/Storages/StorageFile.cpp:956: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321ddfa1 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4655ce 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:51.367830 [ 23593 ] {92591041-8bdf-4ce2-91a2-92554544b232} TCPHandler: Code: 636. DB::Exception: All attempts to extract table structure from files failed. Errors: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.3.12.76.altinitystable) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 6 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.3.12.76.altinitystable) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_jfutmtg3_data2.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033518215 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./build_docker/./src/Storages/StorageFile.cpp:943: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321dd621 7. ./build_docker/./src/Storages/StorageFile.cpp:956: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321ddfa1 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4655ce 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:51.421781 [ 23593 ] {0f3d97e8-6d91-44cf-9d6a-c988b533e44a} executeQuery: Code: 36. DB::Exception: GROUPING function argument number % 3 is not in GROUP BY keys. In query SELECT number, grouping(number, number % 2, number % 3) AS gr FROM numbers(10) GROUP BY GROUPING SETS ((number), (number % 2)) ORDER BY number ASC, gr ASC. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:33294) (comment: 02293_grouping_function.sql) (in query: SELECT number, grouping(number, number % 2, number % 3) AS gr FROM numbers(10) GROUP BY GROUPING SETS ( (number), (number % 2) ) ORDER BY number, gr;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003093e2db 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003093db02 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003093db02 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:269: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093c84c 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:51.422059 [ 23593 ] {0f3d97e8-6d91-44cf-9d6a-c988b533e44a} TCPHandler: Code: 36. DB::Exception: GROUPING function argument number % 3 is not in GROUP BY keys. In query SELECT number, grouping(number, number % 2, number % 3) AS gr FROM numbers(10) GROUP BY GROUPING SETS ((number), (number % 2)) ORDER BY number ASC, gr ASC. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003093e2db 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003093db02 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003093db02 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:269: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093c84c 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:51.562176 [ 23593 ] {0e036629-70ea-4d3f-9ce6-0d47399c92ae} executeQuery: Code: 636. DB::Exception: All attempts to extract table structure from files failed. Errors: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.3.12.76.altinitystable) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.3.12.76.altinitystable) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 4 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.3.12.76.altinitystable) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_jfutmtg3_data3.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.3.12.76.altinitystable) (from [::1]:33310) (comment: 02305_schema_inference_with_globs.sh) (in query: desc file('02305_schema_inference_with_globs_test_jfutmtg3_data*.jsonl') settings input_format_max_rows_to_read_for_schema_inference=24, input_format_json_infer_incomplete_types_as_strings=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033518215 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./build_docker/./src/Storages/StorageFile.cpp:943: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321dd621 7. ./build_docker/./src/Storages/StorageFile.cpp:956: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321ddfa1 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4655ce 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:51.562493 [ 23593 ] {0e036629-70ea-4d3f-9ce6-0d47399c92ae} TCPHandler: Code: 636. DB::Exception: All attempts to extract table structure from files failed. Errors: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.3.12.76.altinitystable) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.3.12.76.altinitystable) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 4 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.3.12.76.altinitystable) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_jfutmtg3_data3.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033518215 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./build_docker/./src/Storages/StorageFile.cpp:943: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321dd621 7. ./build_docker/./src/Storages/StorageFile.cpp:956: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321ddfa1 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e4655ce 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000031792592 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000031790a36 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:52.072118 [ 23593 ] {1e8cbcd9-e2e3-4a47-922d-adbc222b08fa} executeQuery: Code: 62. DB::Exception: AUTO_INCREMENT is not supported. To ignore the keyword in column declaration, set `compatibility_ignore_auto_increment_in_create_table` to true. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:33348) (comment: 02293_compatibility_ignore_auto_increment_in_create_table.sql) (in query: CREATE TABLE ignore_auto_increment ( id int AUTO_INCREMENT ) ENGINE=MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b41b1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:52.072356 [ 23593 ] {1e8cbcd9-e2e3-4a47-922d-adbc222b08fa} TCPHandler: Code: 62. DB::Exception: AUTO_INCREMENT is not supported. To ignore the keyword in column declaration, set `compatibility_ignore_auto_increment_in_create_table` to true. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b41b1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:52.641787 [ 23593 ] {7ff59305-0fe2-4b20-9dcf-f901c0d64bbe} executeQuery: Code: 1. DB::Exception: Expected function, got: x. (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:33378) (comment: 02292_create_function_validate.sql) (in query: create function foo as x -- { serverError UNSUPPORTED_METHOD } ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:0: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x000000003406ab94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x000000003406b498 6. ./build_docker/./src/Interpreters/InterpreterCreateFunctionQuery.cpp:0: DB::InterpreterCreateFunctionQuery::execute() @ 0x00000000317c9c8d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:52.641983 [ 23593 ] {7ff59305-0fe2-4b20-9dcf-f901c0d64bbe} TCPHandler: Code: 1. DB::Exception: Expected function, got: x. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:0: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x000000003406ab94 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x000000003406b498 6. ./build_docker/./src/Interpreters/InterpreterCreateFunctionQuery.cpp:0: DB::InterpreterCreateFunctionQuery::execute() @ 0x00000000317c9c8d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:52.761017 [ 23593 ] {11910379-c739-4214-9ccb-472f5969e983} executeQuery: Code: 43. DB::Exception: Invalid origin H3 index: 37480377652084735: In scope SELECT h3GetUnidirectionalEdge(stringToH3('85283473ffffff'), stringToH3('852\03477fffffff')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:33382) (comment: 02292_h3_unidirectional_funcs.sql) (in query: SELECT h3GetUnidirectionalEdge(stringToH3('85283473ffffff'), stringToH3('852\03477fffffff'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x00000000192fbcfb 4. DB::(anonymous namespace)::FunctionH3GetUnidirectionalEdge::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd4cfb5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:11:52.761259 [ 23593 ] {11910379-c739-4214-9ccb-472f5969e983} TCPHandler: Code: 43. DB::Exception: Invalid origin H3 index: 37480377652084735: In scope SELECT h3GetUnidirectionalEdge(stringToH3('85283473ffffff'), stringToH3('852\03477fffffff')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x00000000192fbcfb 4. DB::(anonymous namespace)::FunctionH3GetUnidirectionalEdge::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd4cfb5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:11:53.907113 [ 1658 ] {f999bd21-e1fc-45c1-8850-fb785e767705} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT L1Norm(1, 2). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:33512) (comment: 02283_array_norm.sql) (in query: SELECT L1Norm(1, 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:53.907317 [ 1658 ] {f999bd21-e1fc-45c1-8850-fb785e767705} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT L1Norm(1, 2). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:53.909111 [ 1658 ] {f75cc80c-74b0-4ef4-a80a-26dea7e541fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 1, should be 2: In scope SELECT LpNorm([1, 2]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:33512) (comment: 02283_array_norm.sql) (in query: SELECT LpNorm([1,2]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:53.909236 [ 1658 ] {f75cc80c-74b0-4ef4-a80a-26dea7e541fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 1, should be 2: In scope SELECT LpNorm([1, 2]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:53.942305 [ 1658 ] {83edec93-4835-4a4c-a918-977947057473} executeQuery: Code: 69. DB::Exception: Second argument for function arrayLpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm([1, 2], -3.4). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:33512) (comment: 02283_array_norm.sql) (in query: SELECT LpNorm([1,2], -3.4);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayNorm::initConstParams(std::vector> const&) const @ 0x0000000023d3a617 5. COW::immutable_ptr DB::FunctionArrayNorm::executeWithTypes(DB::ColumnArray const&, unsigned long, std::vector> const&) const @ 0x0000000023d73c36 6. COW::immutable_ptr DB::FunctionArrayNorm::executeWithResultType(DB::ColumnArray const&, std::shared_ptr const&, unsigned long, std::vector> const&) const @ 0x0000000023d6ba05 7. DB::FunctionArrayNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023d6a664 8. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021cf1349 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:11:53.942487 [ 1658 ] {83edec93-4835-4a4c-a918-977947057473} TCPHandler: Code: 69. DB::Exception: Second argument for function arrayLpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm([1, 2], -3.4). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayNorm::initConstParams(std::vector> const&) const @ 0x0000000023d3a617 5. COW::immutable_ptr DB::FunctionArrayNorm::executeWithTypes(DB::ColumnArray const&, unsigned long, std::vector> const&) const @ 0x0000000023d73c36 6. COW::immutable_ptr DB::FunctionArrayNorm::executeWithResultType(DB::ColumnArray const&, std::shared_ptr const&, unsigned long, std::vector> const&) const @ 0x0000000023d6ba05 7. DB::FunctionArrayNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023d6a664 8. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021cf1349 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:11:53.973529 [ 1658 ] {bc7d6219-c4f0-4d06-941c-046c98ec5571} executeQuery: Code: 43. DB::Exception: Argument p of function arrayLpNorm must be numeric constant: In scope SELECT LpNorm([1, 2], 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:33512) (comment: 02283_array_norm.sql) (in query: SELECT LpNorm([1,2], 'aa');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayNorm::initConstParams(std::vector> const&) const @ 0x0000000023d3a508 5. COW::immutable_ptr DB::FunctionArrayNorm::executeWithTypes(DB::ColumnArray const&, unsigned long, std::vector> const&) const @ 0x0000000023d73c36 6. COW::immutable_ptr DB::FunctionArrayNorm::executeWithResultType(DB::ColumnArray const&, std::shared_ptr const&, unsigned long, std::vector> const&) const @ 0x0000000023d6ba05 7. DB::FunctionArrayNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023d6a664 8. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021cf1349 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:11:53.973778 [ 1658 ] {bc7d6219-c4f0-4d06-941c-046c98ec5571} TCPHandler: Code: 43. DB::Exception: Argument p of function arrayLpNorm must be numeric constant: In scope SELECT LpNorm([1, 2], 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayNorm::initConstParams(std::vector> const&) const @ 0x0000000023d3a508 5. COW::immutable_ptr DB::FunctionArrayNorm::executeWithTypes(DB::ColumnArray const&, unsigned long, std::vector> const&) const @ 0x0000000023d73c36 6. COW::immutable_ptr DB::FunctionArrayNorm::executeWithResultType(DB::ColumnArray const&, std::shared_ptr const&, unsigned long, std::vector> const&) const @ 0x0000000023d6ba05 7. DB::FunctionArrayNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023d6a664 8. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021cf1349 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:11:53.976177 [ 1658 ] {93d7cb98-c271-4444-9ad3-3728898b5faa} executeQuery: Code: 43. DB::Exception: Argument p of function arrayLpNorm must be numeric constant: In scope SELECT LpNorm([1, 2], [1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:33512) (comment: 02283_array_norm.sql) (in query: SELECT LpNorm([1,2], [1]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayNorm::initConstParams(std::vector> const&) const @ 0x0000000023d3a508 5. COW::immutable_ptr DB::FunctionArrayNorm::executeWithTypes(DB::ColumnArray const&, unsigned long, std::vector> const&) const @ 0x0000000023d73c36 6. COW::immutable_ptr DB::FunctionArrayNorm::executeWithResultType(DB::ColumnArray const&, std::shared_ptr const&, unsigned long, std::vector> const&) const @ 0x0000000023d6ba05 7. DB::FunctionArrayNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023d6a664 8. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021cf1349 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:11:53.976282 [ 1658 ] {93d7cb98-c271-4444-9ad3-3728898b5faa} TCPHandler: Code: 43. DB::Exception: Argument p of function arrayLpNorm must be numeric constant: In scope SELECT LpNorm([1, 2], [1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayNorm::initConstParams(std::vector> const&) const @ 0x0000000023d3a508 5. COW::immutable_ptr DB::FunctionArrayNorm::executeWithTypes(DB::ColumnArray const&, unsigned long, std::vector> const&) const @ 0x0000000023d73c36 6. COW::immutable_ptr DB::FunctionArrayNorm::executeWithResultType(DB::ColumnArray const&, std::shared_ptr const&, unsigned long, std::vector> const&) const @ 0x0000000023d6ba05 7. DB::FunctionArrayNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023d6a664 8. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021cf1349 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:11:54.008546 [ 1658 ] {191ba77c-7123-4291-808d-29f1a521f5c1} executeQuery: Code: 44. DB::Exception: Second argument for function arrayLpNorm must be either constant Float64 or constant UInt. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:33512) (comment: 02283_array_norm.sql) (in query: SELECT LpNorm([1,2], materialize(3.14));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayNorm::initConstParams(std::vector> const&) const @ 0x0000000023d3a73a 5. COW::immutable_ptr DB::FunctionArrayNorm::executeWithTypes(DB::ColumnArray const&, unsigned long, std::vector> const&) const @ 0x0000000023d73c36 6. COW::immutable_ptr DB::FunctionArrayNorm::executeWithResultType(DB::ColumnArray const&, std::shared_ptr const&, unsigned long, std::vector> const&) const @ 0x0000000023d6ba05 7. DB::FunctionArrayNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023d6a664 8. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021cf1349 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 16. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 18. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:54.008814 [ 1658 ] {191ba77c-7123-4291-808d-29f1a521f5c1} TCPHandler: Code: 44. DB::Exception: Second argument for function arrayLpNorm must be either constant Float64 or constant UInt. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayNorm::initConstParams(std::vector> const&) const @ 0x0000000023d3a73a 5. COW::immutable_ptr DB::FunctionArrayNorm::executeWithTypes(DB::ColumnArray const&, unsigned long, std::vector> const&) const @ 0x0000000023d73c36 6. COW::immutable_ptr DB::FunctionArrayNorm::executeWithResultType(DB::ColumnArray const&, std::shared_ptr const&, unsigned long, std::vector> const&) const @ 0x0000000023d6ba05 7. DB::FunctionArrayNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023d6a664 8. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021cf1349 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 16. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 18. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:54.378535 [ 14974 ] {7a13724b-e457-4d15-b24f-310d92ea7a3d} executeQuery: Code: 190. DB::Exception: Array arguments for function arrayL1Distance must have equal sizes: In scope SELECT L1Distance([0, 0], [1]). (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:33542) (comment: 02282_array_distance.sql) (in query: SELECT L1Distance([0, 0], [1]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x00000000220fb926 5. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x00000000220ed32a 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x0000000021fd4749 7. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021fd2f47 8. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021cfa669 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:11:54.378776 [ 14974 ] {7a13724b-e457-4d15-b24f-310d92ea7a3d} TCPHandler: Code: 190. DB::Exception: Array arguments for function arrayL1Distance must have equal sizes: In scope SELECT L1Distance([0, 0], [1]). (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x00000000220fb926 5. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x00000000220ed32a 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x0000000021fd4749 7. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021fd2f47 8. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021cfa669 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:11:54.403138 [ 14974 ] {a2a27228-a2c3-4d04-b4c3-fb55807a82bd} executeQuery: Code: 43. DB::Exception: Argument 1 of function arrayL2Distance must be array.: In scope SELECT L2Distance([1, 2], (3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:33542) (comment: 02282_array_distance.sql) (in query: SELECT L2Distance([1, 2], (3,4));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. DB::FunctionArrayDistance::getReturnTypeImpl(std::vector> const&) const @ 0x000000002220a0a8 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:54.403338 [ 14974 ] {a2a27228-a2c3-4d04-b4c3-fb55807a82bd} TCPHandler: Code: 43. DB::Exception: Argument 1 of function arrayL2Distance must be array.: In scope SELECT L2Distance([1, 2], (3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. DB::FunctionArrayDistance::getReturnTypeImpl(std::vector> const&) const @ 0x000000002220a0a8 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:54.428049 [ 14974 ] {aa543576-2175-4fd6-9c71-8de97e03e5e5} executeQuery: Code: 43. DB::Exception: Argument 1 of function arrayL2SquaredDistance must be array.: In scope SELECT L2SquaredDistance([1, 2], (3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:33542) (comment: 02282_array_distance.sql) (in query: SELECT L2SquaredDistance([1, 2], (3,4));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. DB::FunctionArrayDistance::getReturnTypeImpl(std::vector> const&) const @ 0x0000000022434668 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:54.428275 [ 14974 ] {aa543576-2175-4fd6-9c71-8de97e03e5e5} TCPHandler: Code: 43. DB::Exception: Argument 1 of function arrayL2SquaredDistance must be array.: In scope SELECT L2SquaredDistance([1, 2], (3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. DB::FunctionArrayDistance::getReturnTypeImpl(std::vector> const&) const @ 0x0000000022434668 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:54.430349 [ 14974 ] {58b74bef-29db-4f0d-a6a5-08d9838ae9bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT LpDistance([1, 2], [3, 4]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:33542) (comment: 02282_array_distance.sql) (in query: SELECT LpDistance([1, 2], [3,4]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:54.430452 [ 14974 ] {58b74bef-29db-4f0d-a6a5-08d9838ae9bb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT LpDistance([1, 2], [3, 4]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:54.460835 [ 14974 ] {14ce11c3-515e-410c-80a8-8ea8da0485a7} executeQuery: Code: 69. DB::Exception: Second argument for function arrayLpDistance must be not less than one and not be an infinity: In scope SELECT LpDistance([1, 2], [3, 4], -1.). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:33542) (comment: 02282_array_distance.sql) (in query: SELECT LpDistance([1, 2], [3,4], -1.);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayDistance::initConstParams(std::vector> const&) const @ 0x0000000021fd1397 5. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x0000000022796129 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x000000002278874a 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x000000002266b549 8. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000022669da7 9. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021d08de9 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 14. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:11:54.461087 [ 14974 ] {14ce11c3-515e-410c-80a8-8ea8da0485a7} TCPHandler: Code: 69. DB::Exception: Second argument for function arrayLpDistance must be not less than one and not be an infinity: In scope SELECT LpDistance([1, 2], [3, 4], -1.). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayDistance::initConstParams(std::vector> const&) const @ 0x0000000021fd1397 5. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x0000000022796129 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x000000002278874a 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x000000002266b549 8. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000022669da7 9. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021d08de9 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 14. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:11:54.491097 [ 14974 ] {abee8c7f-57a5-424e-b99a-aea5f096c08b} executeQuery: Code: 43. DB::Exception: Argument p of function arrayLpDistance must be numeric constant: In scope SELECT LpDistance([1, 2], [3, 4], 'aaa'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:33542) (comment: 02282_array_distance.sql) (in query: SELECT LpDistance([1, 2], [3,4], 'aaa');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayDistance::initConstParams(std::vector> const&) const @ 0x0000000021fd1288 5. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x0000000022796129 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x000000002278874a 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x000000002266b549 8. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000022669da7 9. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021d08de9 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 14. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:11:54.491271 [ 14974 ] {abee8c7f-57a5-424e-b99a-aea5f096c08b} TCPHandler: Code: 43. DB::Exception: Argument p of function arrayLpDistance must be numeric constant: In scope SELECT LpDistance([1, 2], [3, 4], 'aaa'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayDistance::initConstParams(std::vector> const&) const @ 0x0000000021fd1288 5. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x0000000022796129 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x000000002278874a 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x000000002266b549 8. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000022669da7 9. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021d08de9 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 14. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:11:54.524994 [ 14974 ] {182245cb-76b3-4fcc-887c-eab8e3fdcd04} executeQuery: Code: 44. DB::Exception: Second argument for function arrayLpDistance must be either constant Float64 or constant UInt. (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:33542) (comment: 02282_array_distance.sql) (in query: SELECT LpDistance([1, 2], [3,4], materialize(2.7));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayDistance::initConstParams(std::vector> const&) const @ 0x0000000021fd14ba 5. COW::immutable_ptr DB::FunctionArrayDistance::executeWithLeftArgConst(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x00000000227a4777 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x0000000022795afa 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x000000002278874a 8. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x000000002266b549 9. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000022669da7 10. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021d08de9 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 18. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 20. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 21. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:11:54.525164 [ 14974 ] {182245cb-76b3-4fcc-887c-eab8e3fdcd04} TCPHandler: Code: 44. DB::Exception: Second argument for function arrayLpDistance must be either constant Float64 or constant UInt. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionArrayDistance::initConstParams(std::vector> const&) const @ 0x0000000021fd14ba 5. COW::immutable_ptr DB::FunctionArrayDistance::executeWithLeftArgConst(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x00000000227a4777 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x0000000022795afa 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x000000002278874a 8. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x000000002266b549 9. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000022669da7 10. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021d08de9 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 18. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 20. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 21. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:11:55.961293 [ 23620 ] {fb448e94-b0c5-45f8-80fb-4017aa900fd4} executeQuery: Code: 48. DB::Exception: Cannot support collation, please set compatibility_ignore_collation_in_create_table=true. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:33768) (comment: 02269_create_table_with_collation.sql) (in query: CREATE TABLE t_02267_collation (x varchar(255) COLLATE utf8_unicode_ci NOT NULL) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:533: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b3e9d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:55.961506 [ 23620 ] {fb448e94-b0c5-45f8-80fb-4017aa900fd4} TCPHandler: Code: 48. DB::Exception: Cannot support collation, please set compatibility_ignore_collation_in_create_table=true. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:533: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b3e9d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:56.222261 [ 730 ] {e05d5f9a-8d78-4c94-81b6-8b34f1656d4f} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 27. DB::Exception: Cannot parse input: expected '{' before: '1\n'. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.3.12.76.altinitystable). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02268_data.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.3.12.76.altinitystable) (from [::1]:33798) (comment: 02268_json_wrong_root_type_in_schema_inference.sql) (in query: select * from file('02268_data.jsonl');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:279: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351840a 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./build_docker/./src/Storages/StorageFile.cpp:943: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321dd621 7. ./build_docker/./src/Storages/StorageFile.cpp:956: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321ddfa1 8. ./build_docker/./src/Storages/StorageFile.cpp:1080: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000321dfc9e 9. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000321e1737 10. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000321e2057 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::StorageFile* std::construct_at[abi:v15000](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e468909 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e46874a 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e4684b4 14. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:88: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e464c29 15. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 17. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:11:56.222535 [ 730 ] {e05d5f9a-8d78-4c94-81b6-8b34f1656d4f} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 27. DB::Exception: Cannot parse input: expected '{' before: '1\n'. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.3.12.76.altinitystable). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02268_data.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:279: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351840a 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./build_docker/./src/Storages/StorageFile.cpp:943: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321dd621 7. ./build_docker/./src/Storages/StorageFile.cpp:956: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321ddfa1 8. ./build_docker/./src/Storages/StorageFile.cpp:1080: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000321dfc9e 9. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000321e1737 10. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000321e2057 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::StorageFile* std::construct_at[abi:v15000](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e468909 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e46874a 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e4684b4 14. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:88: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e464c29 15. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 17. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:11:56.231877 [ 730 ] {3ca64dd7-fee9-4a28-8748-d2fb91bd7d3f} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 27. DB::Exception: Cannot parse input: expected '[' before: '1\n'. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.3.12.76.altinitystable). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02268_data.jsonCompactEachRow). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.3.12.76.altinitystable) (from [::1]:33798) (comment: 02268_json_wrong_root_type_in_schema_inference.sql) (in query: select * from file('02268_data.jsonCompactEachRow');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:279: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351840a 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./build_docker/./src/Storages/StorageFile.cpp:943: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321dd621 7. ./build_docker/./src/Storages/StorageFile.cpp:956: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321ddfa1 8. ./build_docker/./src/Storages/StorageFile.cpp:1080: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000321dfc9e 9. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000321e1737 10. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000321e2057 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::StorageFile* std::construct_at[abi:v15000](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e468909 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e46874a 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e4684b4 14. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:88: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e464c29 15. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 17. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:11:56.232034 [ 730 ] {3ca64dd7-fee9-4a28-8748-d2fb91bd7d3f} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 27. DB::Exception: Cannot parse input: expected '[' before: '1\n'. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.3.12.76.altinitystable). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02268_data.jsonCompactEachRow). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:279: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351840a 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./build_docker/./src/Storages/StorageFile.cpp:943: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321dd621 7. ./build_docker/./src/Storages/StorageFile.cpp:956: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321ddfa1 8. ./build_docker/./src/Storages/StorageFile.cpp:1080: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000321dfc9e 9. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000321e1737 10. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000321e2057 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::StorageFile* std::construct_at[abi:v15000](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e468909 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e46874a 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e4684b4 14. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:88: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e464c29 15. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 17. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:11:56.682402 [ 23620 ] {e37a51e5-6cac-492e-998f-a2cfb2285419} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: 'number\tname\n1\tClickHouse\n2\tHello\n3\tHedhehog\n': (at row 1) : Row 1: Column 0, name: c1, type: UInt64, ERROR: text "numbernam" is not like UInt64 : (in file/uri http://localhost:11111/test/tsv_with_header.tsv): While executing TabSeparatedRowInputFormat: While executing URL. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:33832) (comment: 02270_errors_in_files_s3.sh) (in query: SELECT * FROM url('http://localhost:11111/test/{a,tsv_with_header}.tsv', 'TSV', 'c1 UInt64, c2 UInt64, c3 UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./src/IO/ReadHelpers.h:203: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000033ab320d 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9817 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 9. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 13. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 15. ./build_docker/./src/Storages/StorageURL.cpp:406: DB::StorageURLSource::generate() @ 0x00000000326594a1 16. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 17. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 21. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 22. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 23. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:56.682912 [ 23620 ] {e37a51e5-6cac-492e-998f-a2cfb2285419} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: 'number\tname\n1\tClickHouse\n2\tHello\n3\tHedhehog\n': (at row 1) : Row 1: Column 0, name: c1, type: UInt64, ERROR: text "numbernam" is not like UInt64 : (in file/uri http://localhost:11111/test/tsv_with_header.tsv): While executing TabSeparatedRowInputFormat: While executing URL. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./src/IO/ReadHelpers.h:203: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000033ab320d 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9817 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 9. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 13. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 15. ./build_docker/./src/Storages/StorageURL.cpp:406: DB::StorageURLSource::generate() @ 0x00000000326594a1 16. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 17. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 21. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 22. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 23. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:56.905070 [ 22863 ] {64a86ce9-5eab-4c49-8196-8f664d315a51} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: 'number\tname\n1\tClickHouse\n2\tHello\n3\tHedhehog\n': (at row 1) : Row 1: Column 0, name: c1, type: UInt64, ERROR: text "numbernam" is not like UInt64 : (in file/uri test/tsv_with_header.tsv): While executing TabSeparatedRowInputFormat: While executing S3. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:33854) (comment: 02270_errors_in_files_s3.sh) (in query: SELECT * FROM s3('http://localhost:11111/test/{a,tsv_with_header}.tsv', 'TSV', 'c1 UInt64, c2 UInt64, c3 UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./src/IO/ReadHelpers.h:203: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000033ab320d 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9817 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 9. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 13. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 15. ./build_docker/./src/Storages/StorageS3.cpp:794: DB::StorageS3Source::generate() @ 0x00000000325b59b4 16. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 17. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 21. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 22. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 23. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:56.906425 [ 22863 ] {64a86ce9-5eab-4c49-8196-8f664d315a51} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: 'number\tname\n1\tClickHouse\n2\tHello\n3\tHedhehog\n': (at row 1) : Row 1: Column 0, name: c1, type: UInt64, ERROR: text "numbernam" is not like UInt64 : (in file/uri test/tsv_with_header.tsv): While executing TabSeparatedRowInputFormat: While executing S3. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./src/IO/ReadHelpers.h:203: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000033ab320d 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9817 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 9. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 13. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 15. ./build_docker/./src/Storages/StorageS3.cpp:794: DB::StorageS3Source::generate() @ 0x00000000325b59b4 16. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 17. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 21. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 22. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 23. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:57.145477 [ 14974 ] {b4ac3e4a-84e2-490c-af8b-8dbf991e840c} executeQuery: Code: 36. DB::Exception: Cannot reset setting 'ttl' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:33864) (comment: 02252_reset_non_existing_setting.sql) (in query: ALTER TABLE most_ordinary_mt RESET SETTING ttl;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3336: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4287a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:57.148664 [ 14974 ] {b4ac3e4a-84e2-490c-af8b-8dbf991e840c} TCPHandler: Code: 36. DB::Exception: Cannot reset setting 'ttl' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3336: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4287a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:57.154976 [ 14974 ] {c76ee1d3-43d8-4fdd-bf06-0b6d2a44be3c} executeQuery: Code: 36. DB::Exception: Cannot reset setting 'xxx' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:33864) (comment: 02252_reset_non_existing_setting.sql) (in query: ALTER TABLE most_ordinary_mt RESET SETTING allow_remote_fs_zero_copy_replication, xxx;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3336: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4287a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:57.155138 [ 14974 ] {c76ee1d3-43d8-4fdd-bf06-0b6d2a44be3c} TCPHandler: Code: 36. DB::Exception: Cannot reset setting 'xxx' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3336: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4287a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:59.625085 [ 3522 ] {6bbde49f-3b4a-4866-ad50-bcf443475957} executeQuery: Code: 582. DB::Exception: There is no projection pToDro in table. Maybe you meant: ['pToDrop']. (NO_SUCH_PROJECTION_IN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42070) (comment: 02250_hints_for_projections.sh) (in query: ALTER TABLE t DROP PROJECTION pToDro), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Storages/ProjectionsDescription.cpp:0: DB::ProjectionsDescription::remove(String const&, bool) @ 0x000000003212f7f2 5. ./build_docker/./src/Storages/AlterCommands.cpp:765: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003207a358 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000032083bec 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3e11f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:59.625467 [ 3522 ] {6bbde49f-3b4a-4866-ad50-bcf443475957} TCPHandler: Code: 582. DB::Exception: There is no projection pToDro in table. Maybe you meant: ['pToDrop']. (NO_SUCH_PROJECTION_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Storages/ProjectionsDescription.cpp:0: DB::ProjectionsDescription::remove(String const&, bool) @ 0x000000003212f7f2 5. ./build_docker/./src/Storages/AlterCommands.cpp:765: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000003207a358 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000032083bec 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3e11f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:11:59.772028 [ 1863 ] {a152fed8-7915-48fb-8ab0-64f27d760bca} test_oou3n4cn.rmt (ReplicatedMergeTreePartCheckThread): ReplicatedCheckResult DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(const String &, bool): Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/store/d1e/d1e8838d-b8c2-472c-8aa1-e7886dabcd2b/0_0_0_0/columns.txt: , errno: 2, strerror: No such file or directory. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::ErrnoException::ErrnoException(String&&, int, int) @ 0x00000000246e5d9f 4. ./contrib/llvm-project/libcxx/include/string:1499: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x00000000246e5b89 5. ./build_docker/./src/IO/OpenedFile.cpp:33: DB::OpenedFile::open() const @ 0x000000002e901613 6. ./build_docker/./src/IO/OpenedFile.cpp:42: DB::OpenedFile::getFD() const @ 0x000000002e90166d 7. ./src/IO/ReadBufferFromFile.h:101: DB::ReadBufferFromFilePReadWithDescriptorsCache::ReadBufferFromFilePReadWithDescriptorsCache(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000002e8f655d 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&>(String const&, unsigned long&, int&, char*&, unsigned long&, std::optional&, std::shared_ptr const&) @ 0x000000002e8f5d3d 9. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:91: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x000000002e8f4f22 10. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:220: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x000000002e8f4df0 11. ./build_docker/./src/Disks/DiskLocal.cpp:335: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000002f9b546f 12. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:131: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000003297d74e 13. ./build_docker/./src/Storages/MergeTree/checkDataPart.cpp:134: DB::checkDataPart(std::shared_ptr, DB::IDataPartStorage const&, DB::NamesAndTypesList const&, DB::MergeTreeDataPartType const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::ReadSettings const&, bool, std::function, bool&, bool) @ 0x00000000330576b8 14. ./build_docker/./src/Storages/MergeTree/checkDataPart.cpp:423: DB::checkDataPart(std::shared_ptr, bool, bool&, std::function, bool) @ 0x0000000033057197 15. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::ReplicatedMergeTreePartCheckThread::checkPartImpl(String const&, bool) @ 0x0000000032f7bba4 16. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreePartCheckThread.cpp:444: DB::ReplicatedMergeTreePartCheckThread::checkPartAndFix(String const&, std::optional*, bool) @ 0x0000000032f82664 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:9031: DB::StorageReplicatedMergeTree::checkDataNext(std::shared_ptr&) @ 0x00000000325233eb 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::(anonymous namespace)::TableCheckWorkerProcessor::transform(DB::Chunk&) @ 0x00000000317af501 19. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:11:59.772146 [ 1863 ] {a152fed8-7915-48fb-8ab0-64f27d760bca} test_oou3n4cn.rmt (ReplicatedMergeTreePartCheckThread): Part 0_0_0_0 looks broken. Removing it and will try to fetch. 2025.03.05 21:11:59.772177 [ 1863 ] {a152fed8-7915-48fb-8ab0-64f27d760bca} test_oou3n4cn.rmt (ReplicatedMergeTreePartCheckThread): Part 0_0_0_0 exists in ZooKeeper and the local part was broken. Detaching it, removing from ZooKeeper and queueing a fetch. 2025.03.05 21:11:59.772368 [ 1863 ] {a152fed8-7915-48fb-8ab0-64f27d760bca} test_oou3n4cn.rmt (d1e8838d-b8c2-472c-8aa1-e7886dabcd2b): Detached 1 parts covered by broken part 0_0_0_0: 0_0_0_0 2025.03.05 21:11:59.775438 [ 1863 ] {a152fed8-7915-48fb-8ab0-64f27d760bca} InterpreterCheckQuery: Check query for table test_oou3n4cn.rmt (d1e8838d-b8c2-472c-8aa1-e7886dabcd2b) failed, path 0_0_0_0, reason: Part 0_0_0_0 looks broken. Removing it and will try to fetch. 2025.03.05 21:11:59.778595 [ 1032 ] {} test_oou3n4cn.rmt (d1e8838d-b8c2-472c-8aa1-e7886dabcd2b): Directory /var/lib/clickhouse/store/d1e/d1e8838d-b8c2-472c-8aa1-e7886dabcd2b/0_0_0_0 (part to remove) doesn't exist or one of nested files has gone. Most likely this is due to manual removing. This should be discouraged. Ignoring. 2025.03.05 21:12:00.021628 [ 919 ] {} test_oou3n4cn.rmt (ReplicatedMergeTreePartCheckThread): No replica has part covering 0_0_0_0 and a merge is impossible: we didn't find smaller parts with either the same min block or the same max block. 2025.03.05 21:12:00.027846 [ 919 ] {} test_oou3n4cn.rmt (ReplicatedMergeTreePartCheckThread): Part 0_0_0_0 is lost forever. 2025.03.05 21:12:00.064891 [ 3522 ] {78356095-39ae-4a91-8440-6c74e43e7486} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `ToDro` to drop. Maybe you meant: ['ToDrop']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.3.12.76.altinitystable) (from [::1]:42170) (comment: 02250_hints_for_columns.sh) (in query: ALTER TABLE t DROP COLUMN ToDro), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Storages/AlterCommands.cpp:1458: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b0ed 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.065198 [ 3522 ] {78356095-39ae-4a91-8440-6c74e43e7486} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `ToDro` to drop. Maybe you meant: ['ToDrop']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Storages/AlterCommands.cpp:1458: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b0ed 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.108793 [ 22863 ] {} DynamicQueryHandler: Code: 81. DB::Exception: Database non_existing_database does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002fd87e5e 5. ./build_docker/./src/Interpreters/Context.cpp:2302: DB::Context::setCurrentDatabase(String const&) @ 0x000000002fc65e73 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d184d 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:12:00.110822 [ 22863 ] {} DynamicQueryHandler: Code: 81. DB::Exception: Database non_existing_database does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002fd87e5e 5. ./build_docker/./src/Interpreters/Context.cpp:2302: DB::Context::setCurrentDatabase(String const&) @ 0x000000002fc65e73 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d184d 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:12:00.111201 [ 1540 ] {f0e1ef65-5d5c-4cb5-b95f-d3e583b249fa} ReadWriteBufferFromHTTP: Failed to make request to 'http://127.0.0.1:8123/?query=select+12' redirect to 'http://127.0.0.1:8123/?query=select+12'. Error: 'DB::HTTPException: Received error from remote server http://127.0.0.1:8123/?query=select+12. HTTP status code: 404 Not Found, body: Code: 81. DB::Exception: Database non_existing_database does not exist. (UNKNOWN_DATABASE) (version 24.3.12.76.altinitystable) '. Failed at try 1/10. 2025.03.05 21:12:00.133856 [ 23582 ] {f0e1ef65-5d5c-4cb5-b95f-d3e583b249fa} executeQuery: Code: 86. DB::HTTPException: Received error from remote server http://127.0.0.1:8123/?query=select+12. HTTP status code: 404 Not Found, body: Code: 81. DB::Exception: Database non_existing_database does not exist. (UNKNOWN_DATABASE) (version 24.3.12.76.altinitystable) : (in file/uri http://127.0.0.1:8123/?query=select+12): While executing RawBLOBRowInputFormat: While executing URL. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER) (version 24.3.12.76.altinitystable) (from [::1]:42192) (comment: 02244_url_engine_headers_test.sql) (in query: select * from url(url_with_headers, url='http://127.0.0.1:8123?query=select+12', format='RawBLOB');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowInputFormat.cpp:32: DB::RawBLOBRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000033a9f615 14. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 15. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 16. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 17. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 20. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 22. ./build_docker/./src/Storages/StorageURL.cpp:406: DB::StorageURLSource::generate() @ 0x00000000326594a1 23. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 28. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 29. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 30. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 2025.03.05 21:12:00.134175 [ 23582 ] {f0e1ef65-5d5c-4cb5-b95f-d3e583b249fa} TCPHandler: Code: 86. DB::HTTPException: Received error from remote server http://127.0.0.1:8123/?query=select+12. HTTP status code: 404 Not Found, body: Code: 81. DB::Exception: Database non_existing_database does not exist. (UNKNOWN_DATABASE) (version 24.3.12.76.altinitystable) : (in file/uri http://127.0.0.1:8123/?query=select+12): While executing RawBLOBRowInputFormat: While executing URL. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowInputFormat.cpp:32: DB::RawBLOBRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000033a9f615 14. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 15. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 16. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 17. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 20. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 22. ./build_docker/./src/Storages/StorageURL.cpp:406: DB::StorageURLSource::generate() @ 0x00000000326594a1 23. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 28. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 29. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 30. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 2025.03.05 21:12:00.181775 [ 22863 ] {} DynamicQueryHandler: Code: 81. DB::Exception: Database kek does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002fd87e5e 5. ./build_docker/./src/Interpreters/Context.cpp:2302: DB::Context::setCurrentDatabase(String const&) @ 0x000000002fc65e73 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d184d 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:12:00.182929 [ 22863 ] {} DynamicQueryHandler: Code: 81. DB::Exception: Database kek does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002fd87e5e 5. ./build_docker/./src/Interpreters/Context.cpp:2302: DB::Context::setCurrentDatabase(String const&) @ 0x000000002fc65e73 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d184d 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:12:00.183401 [ 11242 ] {dce3e95e-2504-49c1-8b57-9a9b740c7920} ReadWriteBufferFromHTTP: Failed to make request to 'http://127.0.0.1:8123/?query=select+12' redirect to 'http://127.0.0.1:8123/?query=select+12'. Error: 'DB::HTTPException: Received error from remote server http://127.0.0.1:8123/?query=select+12. HTTP status code: 404 Not Found, body: Code: 81. DB::Exception: Database kek does not exist. (UNKNOWN_DATABASE) (version 24.3.12.76.altinitystable) '. Failed at try 1/10. 2025.03.05 21:12:00.184399 [ 23582 ] {dce3e95e-2504-49c1-8b57-9a9b740c7920} executeQuery: Code: 86. DB::HTTPException: Received error from remote server http://127.0.0.1:8123/?query=select+12. HTTP status code: 404 Not Found, body: Code: 81. DB::Exception: Database kek does not exist. (UNKNOWN_DATABASE) (version 24.3.12.76.altinitystable) : (in file/uri http://127.0.0.1:8123/?query=select+12): While executing RawBLOBRowInputFormat: While executing URL. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER) (version 24.3.12.76.altinitystable) (from [::1]:42192) (comment: 02244_url_engine_headers_test.sql) (in query: select * from url(url_with_headers, url='http://127.0.0.1:8123?query=select+12', format='RawBLOB', headers('X-ClickHouse-Database'='kek'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowInputFormat.cpp:32: DB::RawBLOBRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000033a9f615 14. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 15. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 16. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 17. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 20. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 22. ./build_docker/./src/Storages/StorageURL.cpp:406: DB::StorageURLSource::generate() @ 0x00000000326594a1 23. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 28. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 29. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 30. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 2025.03.05 21:12:00.184794 [ 23582 ] {dce3e95e-2504-49c1-8b57-9a9b740c7920} TCPHandler: Code: 86. DB::HTTPException: Received error from remote server http://127.0.0.1:8123/?query=select+12. HTTP status code: 404 Not Found, body: Code: 81. DB::Exception: Database kek does not exist. (UNKNOWN_DATABASE) (version 24.3.12.76.altinitystable) : (in file/uri http://127.0.0.1:8123/?query=select+12): While executing RawBLOBRowInputFormat: While executing URL. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowInputFormat.cpp:32: DB::RawBLOBRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000033a9f615 14. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 15. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 16. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 17. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 20. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 22. ./build_docker/./src/Storages/StorageURL.cpp:406: DB::StorageURLSource::generate() @ 0x00000000326594a1 23. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 28. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 29. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 30. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 2025.03.05 21:12:00.215913 [ 22863 ] {} DynamicQueryHandler: Code: 81. DB::Exception: Database kek does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002fd87e5e 5. ./build_docker/./src/Interpreters/Context.cpp:2302: DB::Context::setCurrentDatabase(String const&) @ 0x000000002fc65e73 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d184d 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:12:00.217024 [ 22863 ] {} DynamicQueryHandler: Code: 81. DB::Exception: Database kek does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002fd87e5e 5. ./build_docker/./src/Interpreters/Context.cpp:2302: DB::Context::setCurrentDatabase(String const&) @ 0x000000002fc65e73 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d184d 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:12:00.217305 [ 11408 ] {dbe31201-9e6e-4b8d-a820-5ffb4f4af038} ReadWriteBufferFromHTTP: Failed to make request to 'http://127.0.0.1:8123/?query=select+12' redirect to 'http://127.0.0.1:8123/?query=select+12'. Error: 'DB::HTTPException: Received error from remote server http://127.0.0.1:8123/?query=select+12. HTTP status code: 404 Not Found, body: Code: 81. DB::Exception: Database kek does not exist. (UNKNOWN_DATABASE) (version 24.3.12.76.altinitystable) '. Failed at try 1/10. 2025.03.05 21:12:00.218184 [ 23582 ] {dbe31201-9e6e-4b8d-a820-5ffb4f4af038} executeQuery: Code: 86. DB::HTTPException: Received error from remote server http://127.0.0.1:8123/?query=select+12. HTTP status code: 404 Not Found, body: Code: 81. DB::Exception: Database kek does not exist. (UNKNOWN_DATABASE) (version 24.3.12.76.altinitystable) : (in file/uri http://127.0.0.1:8123/?query=select+12): While executing RawBLOBRowInputFormat: While executing URL. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER) (version 24.3.12.76.altinitystable) (from [::1]:42192) (comment: 02244_url_engine_headers_test.sql) (in query: SELECT * FROM url('http://127.0.0.1:8123?query=select+12', 'RawBLOB', headers('X-ClickHouse-Format' = '[HIDDEN]', 'X-ClickHouse-Database' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowInputFormat.cpp:32: DB::RawBLOBRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000033a9f615 14. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 15. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 16. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 17. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 20. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 22. ./build_docker/./src/Storages/StorageURL.cpp:406: DB::StorageURLSource::generate() @ 0x00000000326594a1 23. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 28. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 29. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 30. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 2025.03.05 21:12:00.218481 [ 23582 ] {dbe31201-9e6e-4b8d-a820-5ffb4f4af038} TCPHandler: Code: 86. DB::HTTPException: Received error from remote server http://127.0.0.1:8123/?query=select+12. HTTP status code: 404 Not Found, body: Code: 81. DB::Exception: Database kek does not exist. (UNKNOWN_DATABASE) (version 24.3.12.76.altinitystable) : (in file/uri http://127.0.0.1:8123/?query=select+12): While executing RawBLOBRowInputFormat: While executing URL. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowInputFormat.cpp:32: DB::RawBLOBRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000033a9f615 14. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 15. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 16. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 17. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 20. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 22. ./build_docker/./src/Storages/StorageURL.cpp:406: DB::StorageURLSource::generate() @ 0x00000000326594a1 23. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 28. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 29. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 30. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 2025.03.05 21:12:00.244630 [ 23582 ] {4bb8939c-f9f2-4c45-9b9f-df37daf1956b} executeQuery: Code: 36. DB::Exception: Expected string as header value. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:42192) (comment: 02244_url_engine_headers_test.sql) (in query: SELECT * FROM url('http://127.0.0.1:8123?query=select+12', 'RawBLOB', headers('X-ClickHouse-Format' = '[HIDDEN]', 'X-ClickHouse-Database' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageURL.cpp:1466: DB::StorageURL::evalArgsAndCollectHeaders(absl::InlinedVector, 7ul, std::allocator>>&, std::vector>&, std::shared_ptr const&) @ 0x0000000032669c43 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4725f5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.244840 [ 23582 ] {4bb8939c-f9f2-4c45-9b9f-df37daf1956b} TCPHandler: Code: 36. DB::Exception: Expected string as header value. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageURL.cpp:1466: DB::StorageURL::evalArgsAndCollectHeaders(absl::InlinedVector, 7ul, std::allocator>>&, std::vector>&, std::shared_ptr const&) @ 0x0000000032669c43 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::TableFunctionURL::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000002e4725f5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e469eea 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionURL::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e472184 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.319261 [ 23586 ] {8d77215f-0eec-4870-abc7-34aee115c044} executeQuery: Code: 10. DB::Exception: Wrong column. Cannot find column `ToDro` to modify. Maybe you meant: ['ToDrop']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.3.12.76.altinitystable) (from [::1]:42222) (comment: 02250_hints_for_columns.sh) (in query: ALTER TABLE t MODIFY COLUMN ToDro UInt64), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a514 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.319716 [ 23586 ] {8d77215f-0eec-4870-abc7-34aee115c044} TCPHandler: Code: 10. DB::Exception: Wrong column. Cannot find column `ToDro` to modify. Maybe you meant: ['ToDrop']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a514 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.553813 [ 23612 ] {36883ca6-9aec-4ba4-9de3-ce89e0b0ccdb} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `ToDro` to rename. Maybe you meant: ['ToDrop']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.3.12.76.altinitystable) (from [::1]:42266) (comment: 02250_hints_for_columns.sh) (in query: ALTER TABLE t RENAME COLUMN ToDro to ToDropp), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Storages/AlterCommands.cpp:1507: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a66f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.554208 [ 23612 ] {36883ca6-9aec-4ba4-9de3-ce89e0b0ccdb} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `ToDro` to rename. Maybe you meant: ['ToDrop']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Storages/AlterCommands.cpp:1507: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a66f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.588035 [ 23586 ] {4487f0ee-f062-42e6-8da7-db7311108b46} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got Date: In scope SELECT makeDate(CAST(1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:42256) (comment: 02242_make_date.sql) (in query: select makeDate(cast(1980 as Date), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.588210 [ 23586 ] {4487f0ee-f062-42e6-8da7-db7311108b46} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got Date: In scope SELECT makeDate(CAST(1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.590364 [ 23586 ] {5c07cc95-8cc2-4f55-867a-dcd046b54f63} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got Date: In scope SELECT makeDate(CAST(-1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:42256) (comment: 02242_make_date.sql) (in query: select makeDate(cast(-1980 as Date), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.590530 [ 23586 ] {5c07cc95-8cc2-4f55-867a-dcd046b54f63} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got Date: In scope SELECT makeDate(CAST(-1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.592186 [ 23586 ] {5e137e39-6724-4fc3-b635-311c0dfbb798} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got Date32: In scope SELECT makeDate(CAST(1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:42256) (comment: 02242_make_date.sql) (in query: select makeDate(cast(1980 as Date32), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.592323 [ 23586 ] {5e137e39-6724-4fc3-b635-311c0dfbb798} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got Date32: In scope SELECT makeDate(CAST(1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.594982 [ 23586 ] {4d73411b-7a65-4179-badc-0e260a7158aa} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got Date32: In scope SELECT makeDate(CAST(-1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:42256) (comment: 02242_make_date.sql) (in query: select makeDate(cast(-1980 as Date32), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.595133 [ 23586 ] {4d73411b-7a65-4179-badc-0e260a7158aa} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got Date32: In scope SELECT makeDate(CAST(-1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.597138 [ 23586 ] {cbcc1e79-c0fb-499b-af42-f6f38d789bf9} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got DateTime: In scope SELECT makeDate(CAST(1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:42256) (comment: 02242_make_date.sql) (in query: select makeDate(cast(1980 as DateTime), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.597280 [ 23586 ] {cbcc1e79-c0fb-499b-af42-f6f38d789bf9} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got DateTime: In scope SELECT makeDate(CAST(1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.599098 [ 23586 ] {1f15dba7-e97a-4a0a-9861-5cf546051aa3} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got DateTime: In scope SELECT makeDate(CAST(-1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:42256) (comment: 02242_make_date.sql) (in query: select makeDate(cast(-1980 as DateTime), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.599229 [ 23586 ] {1f15dba7-e97a-4a0a-9861-5cf546051aa3} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got DateTime: In scope SELECT makeDate(CAST(-1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.601200 [ 23586 ] {3e6fb37c-9fd7-4041-8821-29e792df861b} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got DateTime64(3): In scope SELECT makeDate(CAST(1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:42256) (comment: 02242_make_date.sql) (in query: select makeDate(cast(1980 as DateTime64), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.601328 [ 23586 ] {3e6fb37c-9fd7-4041-8821-29e792df861b} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got DateTime64(3): In scope SELECT makeDate(CAST(1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.603050 [ 23586 ] {f24ed003-2229-4283-9f71-9056496354b0} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got DateTime64(3): In scope SELECT makeDate(CAST(-1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:42256) (comment: 02242_make_date.sql) (in query: select makeDate(cast(-1980 as DateTime64), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.603174 [ 23586 ] {f24ed003-2229-4283-9f71-9056496354b0} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got DateTime64(3): In scope SELECT makeDate(CAST(-1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.675737 [ 23586 ] {b966ff7f-d7b7-4b18-b1f8-db9eec0c7169} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got String: In scope SELECT makeDate('1980', '10', '20'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:42256) (comment: 02242_make_date.sql) (in query: select makeDate('1980', '10', '20');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.675890 [ 23586 ] {b966ff7f-d7b7-4b18-b1f8-db9eec0c7169} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got String: In scope SELECT makeDate('1980', '10', '20'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.677400 [ 23586 ] {b1d6709d-f439-4069-b6af-a4cd9569a5a5} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got String: In scope SELECT makeDate('-1980', 3, 17). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:42256) (comment: 02242_make_date.sql) (in query: select makeDate('-1980', 3, 17);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.677551 [ 23586 ] {b1d6709d-f439-4069-b6af-a4cd9569a5a5} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got String: In scope SELECT makeDate('-1980', 3, 17). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.679175 [ 23586 ] {8bb8ebbc-5e4c-49e9-9e29-b00b33121dec} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got String: In scope SELECT makeDate('aa', 3, 24). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:42256) (comment: 02242_make_date.sql) (in query: select makeDate('aa', 3, 24);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.679287 [ 23586 ] {8bb8ebbc-5e4c-49e9-9e29-b00b33121dec} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'year' of function makeDate, expected Number, got String: In scope SELECT makeDate('aa', 3, 24). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.680809 [ 23586 ] {710037e9-e7db-43d3-b330-33155c287d7d} executeQuery: Code: 43. DB::Exception: Illegal type of argument #2 'month' of function makeDate, expected Number, got String: In scope SELECT makeDate(1994, 'aa', 24). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:42256) (comment: 02242_make_date.sql) (in query: select makeDate(1994, 'aa', 24);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.680950 [ 23586 ] {710037e9-e7db-43d3-b330-33155c287d7d} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #2 'month' of function makeDate, expected Number, got String: In scope SELECT makeDate(1994, 'aa', 24). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.682493 [ 23586 ] {76247301-4465-4fb3-a8d8-4636e78eeb3c} executeQuery: Code: 43. DB::Exception: Illegal type of argument #3 'day' of function makeDate, expected Number, got String: In scope SELECT makeDate(1984, 3, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:42256) (comment: 02242_make_date.sql) (in query: select makeDate(1984, 3, 'aa');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.682651 [ 23586 ] {76247301-4465-4fb3-a8d8-4636e78eeb3c} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #3 'day' of function makeDate, expected Number, got String: In scope SELECT makeDate(1984, 3, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc239 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.723201 [ 23586 ] {98bbad88-0520-4fc3-98e6-fb737501046d} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for function makeDate provided 1 (UInt16), expected 2 ('year' : Number, 'dayofyear' : Number): In scope SELECT makeDate(1980). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:42256) (comment: 02242_make_date.sql) (in query: select makeDate(1980);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc2f9 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.723441 [ 23586 ] {98bbad88-0520-4fc3-98e6-fb737501046d} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for function makeDate provided 1 (UInt16), expected 2 ('year' : Number, 'dayofyear' : Number): In scope SELECT makeDate(1980). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc2f9 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.725699 [ 23586 ] {13cbdfcf-c310-4238-8c93-8df841295625} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for function makeDate provided 4 (UInt16, UInt8, UInt8, UInt8), expected 2 ('year' : Number, 'dayofyear' : Number): In scope SELECT makeDate(1980, 1, 1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:42256) (comment: 02242_make_date.sql) (in query: select makeDate(1980, 1, 1, 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc2f9 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:00.725823 [ 23586 ] {13cbdfcf-c310-4238-8c93-8df841295625} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for function makeDate provided 4 (UInt16, UInt8, UInt8, UInt8), expected 2 ('year' : Number, 'dayofyear' : Number): In scope SELECT makeDate(1980, 1, 1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e9fc2f9 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:01.170083 [ 23586 ] {38f84593-cd86-4984-be83-1260c4fb58d8} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42316) (comment: 02242_join_rocksdb.sql) (in query: -- can't promote right table type SELECT * FROM (SELECT toUInt64(k) as k FROM t2) as t2 INNER JOIN rdb ON rdb.key == t2.k;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:01.171016 [ 23586 ] {38f84593-cd86-4984-be83-1260c4fb58d8} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:01.214648 [ 23586 ] {b128d073-1d2b-44e6-bc16-64114bcdf22f} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42316) (comment: 02242_join_rocksdb.sql) (in query: SELECT * FROM t1 RIGHT JOIN rdb ON rdb.key == t1.k;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:01.214788 [ 23586 ] {b128d073-1d2b-44e6-bc16-64114bcdf22f} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:01.227395 [ 23586 ] {acf1337d-db34-4283-bf1b-37170e06b99e} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42316) (comment: 02242_join_rocksdb.sql) (in query: SELECT * FROM t1 FULL JOIN rdb ON rdb.key == t1.k;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:01.227548 [ 23586 ] {acf1337d-db34-4283-bf1b-37170e06b99e} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:01.239683 [ 23586 ] {38fe6abf-cef5-4ec4-9f88-2a0d65f03fb7} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42316) (comment: 02242_join_rocksdb.sql) (in query: SELECT * FROM t1 INNER JOIN rdb ON rdb.key + 1 == t1.k;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:01.239854 [ 23586 ] {38fe6abf-cef5-4ec4-9f88-2a0d65f03fb7} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:01.253523 [ 23586 ] {106891d0-46f7-44e6-b7a3-c7621463e390} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42316) (comment: 02242_join_rocksdb.sql) (in query: SELECT * FROM t1 INNER JOIN (SELECT * FROM rdb) AS rdb ON rdb.key == t1.k;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:01.253650 [ 23586 ] {106891d0-46f7-44e6-b7a3-c7621463e390} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:01.265702 [ 23586 ] {1fc15163-7117-4062-8fc9-bddf6313d932} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42316) (comment: 02242_join_rocksdb.sql) (in query: SELECT * FROM t1 RIGHT SEMI JOIN (SELECT * FROM rdb) AS rdb ON rdb.key == t1.k;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:01.265895 [ 23586 ] {1fc15163-7117-4062-8fc9-bddf6313d932} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:01.268796 [ 23586 ] {6f43b016-4046-49cc-bfdc-e4f32cd06d4d} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42316) (comment: 02242_join_rocksdb.sql) (in query: SELECT * FROM t1 RIGHT ANTI JOIN (SELECT * FROM rdb) AS rdb ON rdb.key == t1.k;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:01.268937 [ 23586 ] {6f43b016-4046-49cc-bfdc-e4f32cd06d4d} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:06.971591 [ 10241 ] {b8520f25-2665-4afc-8c50-26b258e1aab4} executeQuery: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT IPv4StringToNum('test'). (CANNOT_PARSE_IPV4) (version 24.3.12.76.altinitystable) (from [::1]:43002) (comment: 02234_cast_to_ip_address.sql) (in query: SELECT IPv4StringToNum('test');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000018202de3 5. DB::FunctionIPv4StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018200da3 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:12:06.971871 [ 10241 ] {b8520f25-2665-4afc-8c50-26b258e1aab4} TCPHandler: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT IPv4StringToNum('test'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000018202de3 5. DB::FunctionIPv4StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018200da3 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:12:07.134964 [ 10241 ] {4e0bc02a-5703-402d-95c6-a20e70423326} executeQuery: Code: 675. DB::Exception: Cannot parse IPv4 test: Cannot parse IPv4 from String: In scope SELECT toIPv4('test'). (CANNOT_PARSE_IPV4) (version 24.3.12.76.altinitystable) (from [::1]:43002) (comment: 02234_cast_to_ip_address.sql) (in query: SELECT toIPv4('test');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000001821879b 4. void DB::(anonymous namespace)::parseImpl(DB::DataTypeIPv4::FieldType&, DB::ReadBuffer&, DateLUTImpl const*, bool) @ 0x0000000018511b75 5. bool DB::callOnIndexAndDataType>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001850cb89 6. DB::(anonymous namespace)::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185069e3 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:12:07.135163 [ 10241 ] {4e0bc02a-5703-402d-95c6-a20e70423326} TCPHandler: Code: 675. DB::Exception: Cannot parse IPv4 test: Cannot parse IPv4 from String: In scope SELECT toIPv4('test'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000001821879b 4. void DB::(anonymous namespace)::parseImpl(DB::DataTypeIPv4::FieldType&, DB::ReadBuffer&, DateLUTImpl const*, bool) @ 0x0000000018511b75 5. bool DB::callOnIndexAndDataType>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001850cb89 6. DB::(anonymous namespace)::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185069e3 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:12:07.226418 [ 10241 ] {93e57c0a-4699-4037-af27-1958caa39717} executeQuery: Code: 70. DB::Exception: IPv6 ::afff:102:304 in column IPv6 is not in IPv4 mapping block: In scope SELECT toIPv4(toIPv6('::afff:1.2.3.4')). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:43002) (comment: 02234_cast_to_ip_address.sql) (in query: SELECT toIPv4(toIPv6('::afff:1.2.3.4'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char (&) [46], String&&) @ 0x0000000018783c30 4. bool DB::callOnIndexAndDataType>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001850dd85 5. DB::(anonymous namespace)::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185069e3 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:12:07.246221 [ 10241 ] {93e57c0a-4699-4037-af27-1958caa39717} TCPHandler: Code: 70. DB::Exception: IPv6 ::afff:102:304 in column IPv6 is not in IPv4 mapping block: In scope SELECT toIPv4(toIPv6('::afff:1.2.3.4')). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char (&) [46], String&&) @ 0x0000000018783c30 4. bool DB::callOnIndexAndDataType>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001850dd85 5. DB::(anonymous namespace)::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185069e3 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:12:07.418149 [ 10241 ] {5c2371a3-dcef-4d4b-ab76-34193ce3e773} executeQuery: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT CAST('test', 'IPv4'). (CANNOT_PARSE_IPV4) (version 24.3.12.76.altinitystable) (from [::1]:43002) (comment: 02234_cast_to_ip_address.sql) (in query: SELECT cast('test' , 'IPv4');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877b363 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018284f0e 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:12:07.431439 [ 10241 ] {5c2371a3-dcef-4d4b-ab76-34193ce3e773} TCPHandler: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT CAST('test', 'IPv4'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877b363 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018284f0e 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:12:07.514532 [ 10241 ] {639c6877-b6dd-4e87-8ad1-f820dc5747f4} executeQuery: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT IPv6StringToNum('test'). (CANNOT_PARSE_IPV6) (version 24.3.12.76.altinitystable) (from [::1]:43002) (comment: 02234_cast_to_ip_address.sql) (in query: SELECT IPv6StringToNum('test');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001820ecf1 5. COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001820c02a 6. DB::FunctionIPv6StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001820b143 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:12:07.545826 [ 10241 ] {639c6877-b6dd-4e87-8ad1-f820dc5747f4} TCPHandler: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT IPv6StringToNum('test'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001820ecf1 5. COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001820c02a 6. DB::FunctionIPv6StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001820b143 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:12:07.603508 [ 10241 ] {9433e6cf-224e-424e-abe6-c7bb66031670} executeQuery: Code: 676. DB::Exception: Cannot parse IPv6 test: Cannot parse IPv6 from String: In scope SELECT toIPv6('test'). (CANNOT_PARSE_IPV6) (version 24.3.12.76.altinitystable) (from [::1]:43002) (comment: 02234_cast_to_ip_address.sql) (in query: SELECT toIPv6('test');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000001821879b 4. bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001851cf32 5. DB::(anonymous namespace)::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018515e83 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:12:07.603711 [ 10241 ] {9433e6cf-224e-424e-abe6-c7bb66031670} TCPHandler: Code: 676. DB::Exception: Cannot parse IPv6 test: Cannot parse IPv6 from String: In scope SELECT toIPv6('test'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000001821879b 4. bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001851cf32 5. DB::(anonymous namespace)::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018515e83 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:12:07.753548 [ 10241 ] {c3b45e6a-0882-477f-8639-6675f65d599b} executeQuery: Code: 676. DB::Exception: Cannot parse IPv6 .1.2.3: Cannot parse IPv6 from String: In scope SELECT toIPv6('::.1.2.3'). (CANNOT_PARSE_IPV6) (version 24.3.12.76.altinitystable) (from [::1]:43002) (comment: 02234_cast_to_ip_address.sql) (in query: SELECT toIPv6('::.1.2.3');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000001821879b 4. bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001851cf32 5. DB::(anonymous namespace)::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018515e83 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:12:07.753725 [ 10241 ] {c3b45e6a-0882-477f-8639-6675f65d599b} TCPHandler: Code: 676. DB::Exception: Cannot parse IPv6 .1.2.3: Cannot parse IPv6 from String: In scope SELECT toIPv6('::.1.2.3'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000001821879b 4. bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001851cf32 5. DB::(anonymous namespace)::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018515e83 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:12:08.285454 [ 10241 ] {efb134dd-a31b-4c5c-93cf-d7bd2a9d858b} executeQuery: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT CAST('test', 'IPv6'). (CANNOT_PARSE_IPV6) (version 24.3.12.76.altinitystable) (from [::1]:43002) (comment: 02234_cast_to_ip_address.sql) (in query: SELECT cast('test' , 'IPv6');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877fa3c 5. COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877be2a 6. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182853ee 7. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:12:08.286412 [ 10241 ] {efb134dd-a31b-4c5c-93cf-d7bd2a9d858b} TCPHandler: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT CAST('test', 'IPv6'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877fa3c 5. COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877be2a 6. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182853ee 7. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:12:10.341621 [ 14974 ] {a8c87dc8-a2b8-4741-a54e-0d41afe19a5b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 1, should be 0: In scope SELECT h3GetRes0Indexes(3). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:57554) (comment: 02212_h3_get_res0_indexes.sql) (in query: SELECT h3GetRes0Indexes(3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:10.341817 [ 14974 ] {a8c87dc8-a2b8-4741-a54e-0d41afe19a5b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 1, should be 0: In scope SELECT h3GetRes0Indexes(3). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:10.762957 [ 23601 ] {c757d8b9-b6b2-4b34-a5a1-987430e0e93c} executeQuery: Code: 56. DB::Exception: Only tables with a Replicated engine or tables which do not store data on disk are allowed in a Replicated database. (UNKNOWN_STORAGE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 02232_allow_only_replicated_engine.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_krv466z1_db.tab_mt UUID 'e8d80d88-c905-4690-a824-601e72cb94a9' (`x` UInt32) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 48685, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 315438538, compact_parts_max_bytes_to_buffer = 372195060, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 11277780, merge_max_block_size = 8918, old_parts_lifetime = 361., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 6, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 22627296, concurrent_part_removal_threshold = 2, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 34972, primary_key_compress_block_size = 72870), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1519: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cd5c4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1c55 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:10.764969 [ 23601 ] {c757d8b9-b6b2-4b34-a5a1-987430e0e93c} executeQuery: Code: 56. DB::Exception: Only tables with a Replicated engine or tables which do not store data on disk are allowed in a Replicated database. (UNKNOWN_STORAGE) (version 24.3.12.76.altinitystable) (from [::1]:57582) (comment: 02232_allow_only_replicated_engine.sh) (in query: CREATE TABLE test_krv466z1_db.tab_mt (`x` UInt32) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 48685, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 315438538, compact_parts_max_bytes_to_buffer = 372195060, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 11277780, merge_max_block_size = 8918, old_parts_lifetime = 361., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 6, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 22627296, concurrent_part_removal_threshold = 2, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 34972, primary_key_compress_block_size = 72870), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1519: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cd5c4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1c55 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:10.765248 [ 23601 ] {c757d8b9-b6b2-4b34-a5a1-987430e0e93c} TCPHandler: Code: 56. DB::Exception: Only tables with a Replicated engine or tables which do not store data on disk are allowed in a Replicated database. (UNKNOWN_STORAGE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1519: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cd5c4 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:293: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x000000002f7c758b 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f7872c2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1c55 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:12.154524 [ 23555 ] {fb00fdda-3545-4c11-afa1-580a5d4d5b2b} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 10.00. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:57806) (comment: 02200_use_skip_indexes.sql) (in query: SELECT * FROM data_02200 WHERE value = 1 SETTINGS use_skip_indexes=0, max_rows_to_read=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:257: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f496ac 6. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:12.154708 [ 23555 ] {fb00fdda-3545-4c11-afa1-580a5d4d5b2b} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 10.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:257: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f496ac 6. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:13.566914 [ 23555 ] {69510f26-83e3-4b53-b1c8-098fc1267b0a} executeQuery: Code: 119. DB::Exception: Table engine is not specified in CREATE query. (ENGINE_REQUIRED) (version 24.3.12.76.altinitystable) (from [::1]:57916) (comment: 02184_default_table_engine.sql) (in query: CREATE TABLE table_02184 (x UInt8);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:916: DB::(anonymous namespace)::setDefaultTableEngine(DB::ASTStorage&, DB::DefaultTableEngine) @ 0x00000000307bc3ab 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000307ba16a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b4cdf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:13.567278 [ 23555 ] {69510f26-83e3-4b53-b1c8-098fc1267b0a} TCPHandler: Code: 119. DB::Exception: Table engine is not specified in CREATE query. (ENGINE_REQUIRED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:916: DB::(anonymous namespace)::setDefaultTableEngine(DB::ASTStorage&, DB::DefaultTableEngine) @ 0x00000000307bc3ab 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000307ba16a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b4cdf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:13.626887 [ 23555 ] {0427b67b-d9f7-48b3-b2d8-b141979cf13d} executeQuery: Code: 42. DB::Exception: ORDER BY or PRIMARY KEY clause is missing. Consider using extended storage definition syntax with ORDER BY or PRIMARY KEY clause. With deprecated old syntax (highly not recommended) storage MergeTree requires 3 to 4 parameters: name of column with date, [sampling element of primary key], primary key expression, index granularity Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/en/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/en/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:57916) (comment: 02184_default_table_engine.sql) (in query: CREATE TABLE table_02184 (x UInt8);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x0000000033072cd1 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000033066e8e 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:13.627080 [ 23555 ] {0427b67b-d9f7-48b3-b2d8-b141979cf13d} TCPHandler: Code: 42. DB::Exception: ORDER BY or PRIMARY KEY clause is missing. Consider using extended storage definition syntax with ORDER BY or PRIMARY KEY clause. With deprecated old syntax (highly not recommended) storage MergeTree requires 3 to 4 parameters: name of column with date, [sampling element of primary key], primary key expression, index granularity Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/en/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/en/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x0000000033072cd1 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000033066e8e 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:13.653614 [ 23555 ] {da3e44d1-31a9-43d8-984f-90f32a34ed93} executeQuery: Code: 36. DB::Exception: You must provide an ORDER BY or PRIMARY KEY expression in the table definition. If you don't want this table to be sorted, use ORDER BY/PRIMARY KEY (). Otherwise, you can use the setting 'create_table_empty_primary_key_by_default' to automatically add an empty primary key to the table definition. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:57916) (comment: 02184_default_table_engine.sql) (in query: CREATE TABLE table_02184 (x UInt8) PARTITION BY x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:542: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306fba3 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:13.653749 [ 23555 ] {da3e44d1-31a9-43d8-984f-90f32a34ed93} TCPHandler: Code: 36. DB::Exception: You must provide an ORDER BY or PRIMARY KEY expression in the table definition. If you don't want this table to be sorted, use ORDER BY/PRIMARY KEY (). Otherwise, you can use the setting 'create_table_empty_primary_key_by_default' to automatically add an empty primary key to the table definition. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:542: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306fba3 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:13.883799 [ 23555 ] {bf59987a-0007-447d-b906-d4df1793d39e} executeQuery: Code: 80. DB::Exception: Database engine must be specified. (INCORRECT_QUERY) (version 24.3.12.76.altinitystable) (from [::1]:57916) (comment: 02184_default_table_engine.sql) (in query: CREATE DATABASE test_02184 ORDER BY kek;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000307aa995 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000307d565a 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:13.883977 [ 23555 ] {bf59987a-0007-447d-b906-d4df1793d39e} TCPHandler: Code: 80. DB::Exception: Database engine must be specified. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000307aa995 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000307d565a 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:13.908975 [ 23555 ] {bc156680-162f-4d1b-8e6f-008734b465a6} executeQuery: Code: 115. DB::Exception: Setting x is neither a builtin setting nor started with the prefix 'SQL_' or 'custom_' registered for user-defined settings. (UNKNOWN_SETTING) (version 24.3.12.76.altinitystable) (from [::1]:57916) (comment: 02184_default_table_engine.sql) (in query: CREATE DATABASE test_02184 SETTINGS x=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::CustomSettingsPrefixes::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x000000002ecdd208 5. ./build_docker/./src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a07 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002eed0ee2 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002fc65656 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x00000000310ce197 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000310cef55 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f7353 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:13.909166 [ 23555 ] {bc156680-162f-4d1b-8e6f-008734b465a6} TCPHandler: Code: 115. DB::Exception: Setting x is neither a builtin setting nor started with the prefix 'SQL_' or 'custom_' registered for user-defined settings. (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::CustomSettingsPrefixes::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x000000002ecdd208 5. ./build_docker/./src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a07 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002eed0ee2 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002fc65656 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x00000000310ce197 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000310cef55 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f7353 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:13.983019 [ 23555 ] {6b771f03-5f7e-433f-bf26-c111fc7b6037} executeQuery: Code: 36. DB::Exception: Engine Memory doesn't support PARTITION_BY, PRIMARY_KEY, ORDER_BY or SAMPLE_BY clauses. Currently only the following engines have support for the feature: [AzureBlobStorage, KeeperMap, HDFS, MaterializedPostgreSQL, S3, OSS, ReplicatedSummingMergeTree, COSN, Redis, MergeTree, ReplicatedReplacingMergeTree, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, Hive, ReplacingMergeTree, ReplicatedAggregatingMergeTree, ReplicatedMergeTree, EmbeddedRocksDB, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, SummingMergeTree, GraphiteMergeTree, CollapsingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:57916) (comment: 02184_default_table_engine.sql) (in query: CREATE TEMPORARY TABLE tmp2 (n int) ORDER BY n;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x000000002493f6a3 4. ./build_docker/./src/Storages/StorageFactory.cpp:171: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x00000000321d82f2 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321d6654 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1345: std::shared_ptr std::__function::__policy_invoker (DB::StorageID const&)>::__call_impl>&)::$_0, std::shared_ptr (DB::StorageID const&)>>(std::__function::__policy_storage const*, DB::StorageID const&) @ 0x00000000307d631a 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:112: DB::TemporaryTableHolder::TemporaryTableHolder(std::shared_ptr, std::function (DB::StorageID const&)> const&, std::shared_ptr const&) @ 0x000000002fd7fbbb 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000307c9114 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:13.983270 [ 23555 ] {6b771f03-5f7e-433f-bf26-c111fc7b6037} TCPHandler: Code: 36. DB::Exception: Engine Memory doesn't support PARTITION_BY, PRIMARY_KEY, ORDER_BY or SAMPLE_BY clauses. Currently only the following engines have support for the feature: [AzureBlobStorage, KeeperMap, HDFS, MaterializedPostgreSQL, S3, OSS, ReplicatedSummingMergeTree, COSN, Redis, MergeTree, ReplicatedReplacingMergeTree, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, Hive, ReplacingMergeTree, ReplicatedAggregatingMergeTree, ReplicatedMergeTree, EmbeddedRocksDB, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, SummingMergeTree, GraphiteMergeTree, CollapsingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x000000002493f6a3 4. ./build_docker/./src/Storages/StorageFactory.cpp:171: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x00000000321d82f2 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321d6654 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1345: std::shared_ptr std::__function::__policy_invoker (DB::StorageID const&)>::__call_impl>&)::$_0, std::shared_ptr (DB::StorageID const&)>>(std::__function::__policy_storage const*, DB::StorageID const&) @ 0x00000000307d631a 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:112: DB::TemporaryTableHolder::TemporaryTableHolder(std::shared_ptr, std::function (DB::StorageID const&)> const&, std::shared_ptr const&) @ 0x000000002fd7fbbb 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000307c9114 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:13.985623 [ 23555 ] {b244628c-1e92-44b6-a247-60f6395ef152} executeQuery: Code: 36. DB::Exception: Engine Memory doesn't support PARTITION_BY, PRIMARY_KEY, ORDER_BY or SAMPLE_BY clauses. Currently only the following engines have support for the feature: [AzureBlobStorage, KeeperMap, HDFS, MaterializedPostgreSQL, S3, OSS, ReplicatedSummingMergeTree, COSN, Redis, MergeTree, ReplicatedReplacingMergeTree, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, Hive, ReplacingMergeTree, ReplicatedAggregatingMergeTree, ReplicatedMergeTree, EmbeddedRocksDB, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, SummingMergeTree, GraphiteMergeTree, CollapsingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:57916) (comment: 02184_default_table_engine.sql) (in query: CREATE TEMPORARY TABLE tmp2 (n int, PRIMARY KEY (n));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x000000002493f6a3 4. ./build_docker/./src/Storages/StorageFactory.cpp:171: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x00000000321d82f2 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321d6654 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1345: std::shared_ptr std::__function::__policy_invoker (DB::StorageID const&)>::__call_impl>&)::$_0, std::shared_ptr (DB::StorageID const&)>>(std::__function::__policy_storage const*, DB::StorageID const&) @ 0x00000000307d631a 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:112: DB::TemporaryTableHolder::TemporaryTableHolder(std::shared_ptr, std::function (DB::StorageID const&)> const&, std::shared_ptr const&) @ 0x000000002fd7fbbb 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000307c9114 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:13.985807 [ 23555 ] {b244628c-1e92-44b6-a247-60f6395ef152} TCPHandler: Code: 36. DB::Exception: Engine Memory doesn't support PARTITION_BY, PRIMARY_KEY, ORDER_BY or SAMPLE_BY clauses. Currently only the following engines have support for the feature: [AzureBlobStorage, KeeperMap, HDFS, MaterializedPostgreSQL, S3, OSS, ReplicatedSummingMergeTree, COSN, Redis, MergeTree, ReplicatedReplacingMergeTree, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, Hive, ReplacingMergeTree, ReplicatedAggregatingMergeTree, ReplicatedMergeTree, EmbeddedRocksDB, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, SummingMergeTree, GraphiteMergeTree, CollapsingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x000000002493f6a3 4. ./build_docker/./src/Storages/StorageFactory.cpp:171: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x00000000321d82f2 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321d6654 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1345: std::shared_ptr std::__function::__policy_invoker (DB::StorageID const&)>::__call_impl>&)::$_0, std::shared_ptr (DB::StorageID const&)>>(std::__function::__policy_storage const*, DB::StorageID const&) @ 0x00000000307d631a 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:112: DB::TemporaryTableHolder::TemporaryTableHolder(std::shared_ptr, std::function (DB::StorageID const&)> const&, std::shared_ptr const&) @ 0x000000002fd7fbbb 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000307c9114 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:14.032959 [ 23555 ] {bd2e9bbb-3a8c-4969-badb-2ff2612eef7e} executeQuery: Code: 119. DB::Exception: Table engine is not specified in CREATE query. (ENGINE_REQUIRED) (version 24.3.12.76.altinitystable) (from [::1]:57916) (comment: 02184_default_table_engine.sql) (in query: CREATE TABLE mem AS SELECT 1 as n;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:916: DB::(anonymous namespace)::setDefaultTableEngine(DB::ASTStorage&, DB::DefaultTableEngine) @ 0x00000000307bc3ab 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000307ba16a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b4cdf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:14.042353 [ 23555 ] {bd2e9bbb-3a8c-4969-badb-2ff2612eef7e} TCPHandler: Code: 119. DB::Exception: Table engine is not specified in CREATE query. (ENGINE_REQUIRED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:916: DB::(anonymous namespace)::setDefaultTableEngine(DB::ASTStorage&, DB::DefaultTableEngine) @ 0x00000000307bc3ab 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000307ba16a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b4cdf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:14.072740 [ 23555 ] {541acac4-9ea0-4126-ae97-907b60f695d9} executeQuery: Code: 36. DB::Exception: Engine Memory doesn't support PARTITION_BY, PRIMARY_KEY, ORDER_BY or SAMPLE_BY clauses. Currently only the following engines have support for the feature: [AzureBlobStorage, KeeperMap, HDFS, MaterializedPostgreSQL, S3, OSS, ReplicatedSummingMergeTree, COSN, Redis, MergeTree, ReplicatedReplacingMergeTree, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, Hive, ReplacingMergeTree, ReplicatedAggregatingMergeTree, ReplicatedMergeTree, EmbeddedRocksDB, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, SummingMergeTree, GraphiteMergeTree, CollapsingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:57916) (comment: 02184_default_table_engine.sql) (in query: CREATE TABLE mem ORDER BY n AS SELECT 1 as n;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x000000002493f6a3 4. ./build_docker/./src/Storages/StorageFactory.cpp:171: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x00000000321d82f2 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321d6654 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:14.104095 [ 3522 ] {e1a9ee5b-d73f-4d26-a38b-7b24287ddba3} executeQuery: Code: 36. DB::Exception: No such attribute 'value': In scope SELECT dictGet('02183_flat_dictionary', 'value', 0). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:57960) (comment: 02183_dictionary_no_attributes.sql) (in query: SELECT dictGet('02183_flat_dictionary', 'value', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:184: DB::DictionaryStructure::getAttribute(String const&) const @ 0x000000002e83c49c 5. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000188124d8 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:14.104107 [ 23555 ] {541acac4-9ea0-4126-ae97-907b60f695d9} TCPHandler: Code: 36. DB::Exception: Engine Memory doesn't support PARTITION_BY, PRIMARY_KEY, ORDER_BY or SAMPLE_BY clauses. Currently only the following engines have support for the feature: [AzureBlobStorage, KeeperMap, HDFS, MaterializedPostgreSQL, S3, OSS, ReplicatedSummingMergeTree, COSN, Redis, MergeTree, ReplicatedReplacingMergeTree, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, Hive, ReplacingMergeTree, ReplicatedAggregatingMergeTree, ReplicatedMergeTree, EmbeddedRocksDB, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, SummingMergeTree, GraphiteMergeTree, CollapsingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x000000002493f6a3 4. ./build_docker/./src/Storages/StorageFactory.cpp:171: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const::$_0::operator()(String, std::function) const @ 0x00000000321d82f2 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321d6654 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:14.104771 [ 3522 ] {e1a9ee5b-d73f-4d26-a38b-7b24287ddba3} TCPHandler: Code: 36. DB::Exception: No such attribute 'value': In scope SELECT dictGet('02183_flat_dictionary', 'value', 0). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:184: DB::DictionaryStructure::getAttribute(String const&) const @ 0x000000002e83c49c 5. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000188124d8 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:14.689712 [ 23590 ] {677f3c3a-e3d8-4086-bf5f-b13f35599a10} executeQuery: Code: 6. DB::Exception: Cannot parse string 'Test' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope WITH map(1, 'Test') AS value, 'Array(Tuple(UInt64, UInt64))' AS type SELECT value, CAST(value, type), CAST(materialize(value), type). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:58016) (comment: 02179_map_cast_to_array.sql) (in query: WITH map(1, 'Test') AS value, 'Array(Tuple(UInt64, UInt64))' AS type SELECT value, cast(value, type), cast(materialize(value), type);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182e9b67 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182e12ef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeTuple const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001853c303 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeArray const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001853ad53 15. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 16. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 17. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 19. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 21. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 22. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 23. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 26. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 27. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 2025.03.05 21:12:14.689967 [ 23590 ] {677f3c3a-e3d8-4086-bf5f-b13f35599a10} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'Test' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope WITH map(1, 'Test') AS value, 'Array(Tuple(UInt64, UInt64))' AS type SELECT value, CAST(value, type), CAST(materialize(value), type). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182e9b67 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182e12ef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeTuple const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001853c303 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeArray const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001853ad53 15. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 16. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 17. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 19. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 21. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 22. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 23. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 26. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 27. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 2025.03.05 21:12:14.776724 [ 23590 ] {7816202a-d50a-48af-8774-ad7632624862} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.3.12.76.altinitystable) (from [::1]:58040) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:14.776892 [ 23590 ] {7816202a-d50a-48af-8774-ad7632624862} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:14.942712 [ 23590 ] {f082f789-d371-4adf-9b24-2772d0ad8687} executeQuery: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(Tuple(UInt64)): In scope SELECT mapApply((k, v) -> tuple(v + 9223372036854775806), col) FROM table_map. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapApply((k, v) -> tuple(v + 9223372036854775806), col) FROM table_map;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:0: DB::DataTypeMap::DataTypeMap(std::shared_ptr const&) @ 0x000000002f4d22ca 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]>(std::allocator, std::shared_ptr&&) @ 0x0000000021dc549c 6. std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x0000000021dc5200 7. DB::MapToNestedAdapter::wrapType(std::shared_ptr) @ 0x0000000021ec2c8a 8. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021ebc7d4 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:12:14.942999 [ 23590 ] {f082f789-d371-4adf-9b24-2772d0ad8687} TCPHandler: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(Tuple(UInt64)): In scope SELECT mapApply((k, v) -> tuple(v + 9223372036854775806), col) FROM table_map. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:0: DB::DataTypeMap::DataTypeMap(std::shared_ptr const&) @ 0x000000002f4d22ca 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]>(std::allocator, std::shared_ptr&&) @ 0x0000000021dc549c 6. std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x0000000021dc5200 7. DB::MapToNestedAdapter::wrapType(std::shared_ptr) @ 0x0000000021ec2c8a 8. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021ebc7d4 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:12:14.958957 [ 14920 ] {f1980965-5763-4325-adbb-7e40e97f98b5} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a ORC format file. Error: std::exception. Code: 1001, type: orc::ParseError, e.what() = Footer is corrupt: STRUCT type 0 has 3 subTypes, but has 2 fieldNames (version 24.3.12.76.altinitystable). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/corrupted.orc). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.3.12.76.altinitystable) (from [::1]:58074) (comment: 02185_orc_corrupted_file.sh) (in query: select * from file('corrupted.orc')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:279: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351840a 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./build_docker/./src/Storages/StorageFile.cpp:943: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321dd621 7. ./build_docker/./src/Storages/StorageFile.cpp:956: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321ddfa1 8. ./build_docker/./src/Storages/StorageFile.cpp:1080: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000321dfc9e 9. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000321e1737 10. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000321e2057 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::StorageFile* std::construct_at[abi:v15000](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e468909 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e46874a 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e4684b4 14. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:88: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e464c29 15. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 17. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:12:14.959376 [ 14920 ] {f1980965-5763-4325-adbb-7e40e97f98b5} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a ORC format file. Error: std::exception. Code: 1001, type: orc::ParseError, e.what() = Footer is corrupt: STRUCT type 0 has 3 subTypes, but has 2 fieldNames (version 24.3.12.76.altinitystable). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/corrupted.orc). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:279: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351840a 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:541: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003351990d 6. ./build_docker/./src/Storages/StorageFile.cpp:943: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321dd621 7. ./build_docker/./src/Storages/StorageFile.cpp:956: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000321ddfa1 8. ./build_docker/./src/Storages/StorageFile.cpp:1080: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000321dfc9e 9. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000321e1737 10. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000321e2057 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::StorageFile* std::construct_at[abi:v15000](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e468909 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e46874a 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000002e4684b4 14. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:88: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e464c29 15. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 17. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:12:15.163153 [ 23590 ] {d341874b-db72-49f8-ab74-b37d51078bb3} executeQuery: Code: 42. DB::Exception: Function mapApply requires at least one argument, passed 0: In scope SELECT mapApply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapApply();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000001806a053 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021ebc8e2 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.163304 [ 23590 ] {d341874b-db72-49f8-ab74-b37d51078bb3} TCPHandler: Code: 42. DB::Exception: Function mapApply requires at least one argument, passed 0: In scope SELECT mapApply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000001806a053 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021ebc8e2 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.197543 [ 23590 ] {2aec55ca-7b1d-4fb9-beb5-1a3ed352d274} executeQuery: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(UInt8): In scope SELECT mapApply((x, y) -> x, map(1, 0, 2, 0)). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapApply((x, y) -> (x), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:0: DB::DataTypeMap::DataTypeMap(std::shared_ptr const&) @ 0x000000002f4d2122 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]>(std::allocator, std::shared_ptr&&) @ 0x0000000021dc549c 6. std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x0000000021dc5200 7. DB::MapToNestedAdapter::wrapType(std::shared_ptr) @ 0x0000000021ec2c8a 8. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021ebc7d4 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:12:15.197730 [ 23590 ] {2aec55ca-7b1d-4fb9-beb5-1a3ed352d274} TCPHandler: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(UInt8): In scope SELECT mapApply((x, y) -> x, map(1, 0, 2, 0)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:0: DB::DataTypeMap::DataTypeMap(std::shared_ptr const&) @ 0x000000002f4d2122 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]>(std::allocator, std::shared_ptr&&) @ 0x0000000021dc549c 6. std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x0000000021dc5200 7. DB::MapToNestedAdapter::wrapType(std::shared_ptr) @ 0x0000000021ec2c8a 8. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021ebc7d4 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:12:15.200197 [ 23590 ] {a11ab2f3-98dc-417e-ad69-611ebbeafb5c} executeQuery: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(String): In scope SELECT mapApply((x, y) -> 'x', map(1, 0, 2, 0)). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapApply((x, y) -> ('x'), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:0: DB::DataTypeMap::DataTypeMap(std::shared_ptr const&) @ 0x000000002f4d2122 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]>(std::allocator, std::shared_ptr&&) @ 0x0000000021dc549c 6. std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x0000000021dc5200 7. DB::MapToNestedAdapter::wrapType(std::shared_ptr) @ 0x0000000021ec2c8a 8. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021ebc7d4 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:12:15.200312 [ 23590 ] {a11ab2f3-98dc-417e-ad69-611ebbeafb5c} TCPHandler: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(String): In scope SELECT mapApply((x, y) -> 'x', map(1, 0, 2, 0)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:0: DB::DataTypeMap::DataTypeMap(std::shared_ptr const&) @ 0x000000002f4d2122 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]>(std::allocator, std::shared_ptr&&) @ 0x0000000021dc549c 6. std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x0000000021dc5200 7. DB::MapToNestedAdapter::wrapType(std::shared_ptr) @ 0x0000000021ec2c8a 8. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021ebc7d4 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:12:15.234639 [ 23590 ] {923bda31-1b4b-46ae-ac0b-04955c135a9f} executeQuery: Code: 36. DB::Exception: Type of Map key must be a type, that can be represented by integer or String or FixedString (possibly LowCardinality) or UUID or IPv6, but Tuple(UInt8, UInt8) given: In scope SELECT mapApply(x -> (x, x), map(1, 0, 2, 0)). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapApply((x) -> (x, x), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:0: DB::DataTypeMap::assertKeyType() const @ 0x000000002f4d2764 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:45: DB::DataTypeMap::DataTypeMap(std::shared_ptr const&) @ 0x000000002f4d1dd2 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]>(std::allocator, std::shared_ptr&&) @ 0x0000000021dc549c 7. std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x0000000021dc5200 8. DB::MapToNestedAdapter::wrapType(std::shared_ptr) @ 0x0000000021ec2c8a 9. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021ebc7d4 10. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 11. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 12. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:12:15.234976 [ 23590 ] {923bda31-1b4b-46ae-ac0b-04955c135a9f} TCPHandler: Code: 36. DB::Exception: Type of Map key must be a type, that can be represented by integer or String or FixedString (possibly LowCardinality) or UUID or IPv6, but Tuple(UInt8, UInt8) given: In scope SELECT mapApply(x -> (x, x), map(1, 0, 2, 0)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:0: DB::DataTypeMap::assertKeyType() const @ 0x000000002f4d2764 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:45: DB::DataTypeMap::DataTypeMap(std::shared_ptr const&) @ 0x000000002f4d1dd2 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]>(std::allocator, std::shared_ptr&&) @ 0x0000000021dc549c 7. std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x0000000021dc5200 8. DB::MapToNestedAdapter::wrapType(std::shared_ptr) @ 0x0000000021ec2c8a 9. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021ebc7d4 10. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 11. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 12. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:12:15.238079 [ 23590 ] {8e7f6a93-4af4-4451-8a2f-3d80e5003be7} executeQuery: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(Tuple(UInt8, UInt8, UInt8)): In scope SELECT mapApply((x, y) -> (x, 1, 2), map(1, 0, 2, 0)). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapApply((x, y) -> (x, 1, 2), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:0: DB::DataTypeMap::DataTypeMap(std::shared_ptr const&) @ 0x000000002f4d22ca 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]>(std::allocator, std::shared_ptr&&) @ 0x0000000021dc549c 6. std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x0000000021dc5200 7. DB::MapToNestedAdapter::wrapType(std::shared_ptr) @ 0x0000000021ec2c8a 8. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021ebc7d4 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:12:15.238272 [ 23590 ] {8e7f6a93-4af4-4451-8a2f-3d80e5003be7} TCPHandler: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(Tuple(UInt8, UInt8, UInt8)): In scope SELECT mapApply((x, y) -> (x, 1, 2), map(1, 0, 2, 0)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:0: DB::DataTypeMap::DataTypeMap(std::shared_ptr const&) @ 0x000000002f4d22ca 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]>(std::allocator, std::shared_ptr&&) @ 0x0000000021dc549c 6. std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x0000000021dc5200 7. DB::MapToNestedAdapter::wrapType(std::shared_ptr) @ 0x0000000021ec2c8a 8. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021ebc7d4 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:12:15.266209 [ 23590 ] {3f33b32f-eb0c-489f-829f-209f35b69170} executeQuery: Code: 43. DB::Exception: Function mapApply requires at least one argument of type Map. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapApply((x, y) -> (x, x + 1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::MapAdapterBase, DB::NameMapApply>::extractNestedTypes(std::vector, std::allocator>>&) @ 0x0000000021ec2fb5 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000021ebcae3 6. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ae00b 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.266392 [ 23590 ] {3f33b32f-eb0c-489f-829f-209f35b69170} TCPHandler: Code: 43. DB::Exception: Function mapApply requires at least one argument of type Map. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::MapAdapterBase, DB::NameMapApply>::extractNestedTypes(std::vector, std::allocator>>&) @ 0x0000000021ec2fb5 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000021ebcae3 6. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ae00b 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.291189 [ 23590 ] {1b8c2ce4-7401-46a7-9b09-7177d2639ed0} executeQuery: Code: 43. DB::Exception: Argument 2 of function arrayMap must be Array. Found Function((?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapApply(map(1, 0, 2, 0), (x, y) -> (x, x + 1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&) @ 0x0000000020165b51 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000021ec1732 5. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ae00b 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.291437 [ 23590 ] {1b8c2ce4-7401-46a7-9b09-7177d2639ed0} TCPHandler: Code: 43. DB::Exception: Argument 2 of function arrayMap must be Array. Found Function((?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&) @ 0x0000000020165b51 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000021ec1732 5. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ae00b 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.323593 [ 23590 ] {70ec4fde-2f08-4919-9803-40b8f51eda12} executeQuery: Code: 43. DB::Exception: Illegal types Tuple(UInt8, UInt8) and UInt8 of arguments of function plus: In scope (x, y) -> (x, x + 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapApply((x, y) -> (x, x+1), map(1, 0, 2, 0), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000020c2b00c 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c0fcf 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308af300 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:12:15.323843 [ 23590 ] {70ec4fde-2f08-4919-9803-40b8f51eda12} TCPHandler: Code: 43. DB::Exception: Illegal types Tuple(UInt8, UInt8) and UInt8 of arguments of function plus: In scope (x, y) -> (x, x + 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000020c2b00c 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c0fcf 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308af300 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:12:15.349649 [ 23590 ] {184b0fba-829f-451c-a865-71ce469f5220} executeQuery: Code: 42. DB::Exception: Function mapFilter requires at least one argument, passed 0: In scope SELECT mapFilter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapFilter();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000001806a053 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eb10e2 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.349880 [ 23590 ] {184b0fba-829f-451c-a865-71ce469f5220} TCPHandler: Code: 42. DB::Exception: Function mapFilter requires at least one argument, passed 0: In scope SELECT mapFilter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000001806a053 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eb10e2 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.376788 [ 23590 ] {50aec416-d9d8-4882-b9d0-db90b0229f74} executeQuery: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found Int32: In scope SELECT mapFilter((x, y) -> toInt32(x), map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapFilter((x, y) -> (toInt32(x)), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eb60de 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eb0fc9 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.377052 [ 23590 ] {50aec416-d9d8-4882-b9d0-db90b0229f74} TCPHandler: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found Int32: In scope SELECT mapFilter((x, y) -> toInt32(x), map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eb60de 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eb0fc9 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.379411 [ 23590 ] {18a167ab-96ae-47ad-ac65-8ace33e02664} executeQuery: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found String: In scope SELECT mapFilter((x, y) -> 'x', map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapFilter((x, y) -> ('x'), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eb60de 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eb0fc9 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.379530 [ 23590 ] {18a167ab-96ae-47ad-ac65-8ace33e02664} TCPHandler: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found String: In scope SELECT mapFilter((x, y) -> 'x', map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eb60de 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eb0fc9 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.381303 [ 23590 ] {f3e73889-50fe-4228-8a6d-5cc9cb47b5dc} executeQuery: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found Tuple(Tuple(UInt8, UInt8), Tuple(UInt8, UInt8)): In scope SELECT mapFilter(x -> (x, x), map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapFilter((x) -> (x, x), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eb60de 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eb0fc9 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.381409 [ 23590 ] {f3e73889-50fe-4228-8a6d-5cc9cb47b5dc} TCPHandler: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found Tuple(Tuple(UInt8, UInt8), Tuple(UInt8, UInt8)): In scope SELECT mapFilter(x -> (x, x), map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eb60de 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eb0fc9 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.383160 [ 23590 ] {8736e968-ed6e-451f-ade2-57ff63277542} executeQuery: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found Tuple(UInt8, UInt8, UInt8): In scope SELECT mapFilter((x, y) -> (x, 1, 2), map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapFilter((x, y) -> (x, 1, 2), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eb60de 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eb0fc9 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.383267 [ 23590 ] {8736e968-ed6e-451f-ade2-57ff63277542} TCPHandler: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found Tuple(UInt8, UInt8, UInt8): In scope SELECT mapFilter((x, y) -> (x, 1, 2), map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eb60de 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eb0fc9 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.407984 [ 23590 ] {a6bad75c-5a72-424a-97ad-054e3276a769} executeQuery: Code: 43. DB::Exception: Function mapFilter requires at least one argument of type Map. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapFilter((x, y) -> (x, x + 1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::MapAdapterBase, DB::NameMapFilter>::extractNestedTypes(std::vector, std::allocator>>&) @ 0x0000000021ebb535 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000021eb12e3 6. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ae00b 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.408182 [ 23590 ] {a6bad75c-5a72-424a-97ad-054e3276a769} TCPHandler: Code: 43. DB::Exception: Function mapFilter requires at least one argument of type Map. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. DB::MapAdapterBase, DB::NameMapFilter>::extractNestedTypes(std::vector, std::allocator>>&) @ 0x0000000021ebb535 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000021eb12e3 6. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ae00b 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.433713 [ 23590 ] {282d26d8-3da9-4b0e-9d76-d431e95df032} executeQuery: Code: 43. DB::Exception: Argument 2 of function arrayFilter must be Array. Found Function((?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapFilter(map(1, 0, 2, 0), (x, y) -> (x > 0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&) @ 0x0000000020165b51 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000021eb7212 5. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ae00b 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.433985 [ 23590 ] {282d26d8-3da9-4b0e-9d76-d431e95df032} TCPHandler: Code: 43. DB::Exception: Argument 2 of function arrayFilter must be Array. Found Function((?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&) @ 0x0000000020165b51 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000021eb7212 5. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ae00b 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.436922 [ 23590 ] {106ad8d8-4948-47fe-91ce-4b2535cddc4e} executeQuery: Code: 43. DB::Exception: Illegal types Tuple(UInt8, UInt8) and UInt8 of arguments of function plus: In scope (x, y) -> (x, x + 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapFilter((x, y) -> (x, x + 1), map(1, 0, 2, 0), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000020c2b00c 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c0fcf 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308af300 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:12:15.437156 [ 23590 ] {106ad8d8-4948-47fe-91ce-4b2535cddc4e} TCPHandler: Code: 43. DB::Exception: Illegal types Tuple(UInt8, UInt8) and UInt8 of arguments of function plus: In scope (x, y) -> (x, x + 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000020c2b00c 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c0fcf 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308af300 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:12:15.466053 [ 23590 ] {fa0c4c68-070e-45a3-b866-794d732e47f7} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt8, Tuple(UInt8, UInt8) because some of them are Tuple and some of them are not: In scope SELECT mapConcat([1, 2], map(1, 2)). (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapConcat([1, 2], map(1, 2));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58eebc 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:299: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58c9c2 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 8. DB::FunctionMapToArrayAdapter, DB::NameMapConcat>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021dc4389 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:12:15.466250 [ 23590 ] {fa0c4c68-070e-45a3-b866-794d732e47f7} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt8, Tuple(UInt8, UInt8) because some of them are Tuple and some of them are not: In scope SELECT mapConcat([1, 2], map(1, 2)). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58eebc 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:299: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58c9c2 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 8. DB::FunctionMapToArrayAdapter, DB::NameMapConcat>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021dc4389 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:12:15.495605 [ 23590 ] {350d5b4c-5f71-4a76-906c-bbd1baefaddb} executeQuery: Code: 43. DB::Exception: First argument for function arraySort must be a function. Actual Array(Tuple(UInt8, UInt8)): In scope SELECT mapSort(map(1, 2), map(3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapSort(map(1, 2), map(3, 4));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionArrayMapped, DB::NameArraySort>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eda56b 5. DB::FunctionMapToArrayAdapter, DB::NameArraySort>, DB::MapToNestedAdapter, DB::NameMapSort>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021ed6289 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.495859 [ 23590 ] {350d5b4c-5f71-4a76-906c-bbd1baefaddb} TCPHandler: Code: 43. DB::Exception: First argument for function arraySort must be a function. Actual Array(Tuple(UInt8, UInt8)): In scope SELECT mapSort(map(1, 2), map(3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::FunctionArrayMapped, DB::NameArraySort>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021eda56b 5. DB::FunctionMapToArrayAdapter, DB::NameArraySort>, DB::MapToNestedAdapter, DB::NameMapSort>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021ed6289 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.497648 [ 23590 ] {925e4096-e573-4500-a936-8f1ee2a2aca4} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 0, should be 2: In scope SELECT mapUpdate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapUpdate();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.497820 [ 23590 ] {925e4096-e573-4500-a936-8f1ee2a2aca4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 0, should be 2: In scope SELECT mapUpdate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.499935 [ 23590 ] {899b3d35-0a36-4845-a06a-f3e9e0da3a4b} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate(map(1, 3, 3, 2), map(1, 0, 2, 0), map(1, 0, 2, 0)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:58054) (comment: 02169_map_functions.sql) (in query: SELECT mapUpdate(map(1, 3, 3, 2), map(1, 0, 2, 0), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:15.500066 [ 23590 ] {899b3d35-0a36-4845-a06a-f3e9e0da3a4b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate(map(1, 3, 3, 2), map(1, 0, 2, 0), map(1, 0, 2, 0)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:16.017424 [ 23597 ] {1a4f2b0c-76df-40f4-9934-85f6e18aa8f7} executeQuery: Code: 1. DB::Exception: Resolve identifier '_shard_num' from parent scope only supported for constants and CTE. Actual a._shard_num node type COLUMN. In scope SELECT _shard_num FROM system.one. (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:58152) (comment: 02163_shard_num.sql) (in query: SELECT _shard_num FROM remote('127.1', system.one) AS a INNER JOIN (SELECT _shard_num FROM system.one) AS b USING (dummy);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, char const*&&, String&&) @ 0x000000003092270a 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089cca0 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6519: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882639 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7911: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd42 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7732: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dc28f 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:16.017716 [ 23597 ] {1a4f2b0c-76df-40f4-9934-85f6e18aa8f7} TCPHandler: Code: 1. DB::Exception: Resolve identifier '_shard_num' from parent scope only supported for constants and CTE. Actual a._shard_num node type COLUMN. In scope SELECT _shard_num FROM system.one. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, char const*&&, String&&) @ 0x000000003092270a 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089cca0 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6519: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882639 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7911: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd42 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7732: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dc28f 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:18.759363 [ 23553 ] {523b2359-0f9a-4830-b07e-94823f2adbca} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 12.00, current rows: 28.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:58384) (comment: 02155_read_in_order_max_rows_to_read.sql) (in query: SELECT a FROM t_max_rows_to_read ORDER BY a LIMIT 20 FORMAT Null SETTINGS max_rows_to_read = 12;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f3d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:18.759580 [ 23553 ] {523b2359-0f9a-4830-b07e-94823f2adbca} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 12.00, current rows: 28.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f3d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:18.764094 [ 23553 ] {70c33dde-dac5-429c-b154-261c775a24ec} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 12.00, current rows: 92.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:58384) (comment: 02155_read_in_order_max_rows_to_read.sql) (in query: SELECT a FROM t_max_rows_to_read WHERE a > 10 ORDER BY a LIMIT 5 FORMAT Null SETTINGS max_rows_to_read = 12;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f3d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:18.764213 [ 23553 ] {70c33dde-dac5-429c-b154-261c775a24ec} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 12.00, current rows: 92.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f3d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:18.766557 [ 23553 ] {9c26581c-e194-49f8-a0fa-5b0e97a5e1cd} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 4.00, current rows: 12.00. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:58384) (comment: 02155_read_in_order_max_rows_to_read.sql) (in query: SELECT a FROM t_max_rows_to_read WHERE a = 10 OR a = 20 FORMAT Null SETTINGS max_rows_to_read = 4;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:257: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f496ac 6. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:18.766654 [ 23553 ] {9c26581c-e194-49f8-a0fa-5b0e97a5e1cd} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 4.00, current rows: 12.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:257: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f496ac 6. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:22.742702 [ 23498 ] {} DynamicQueryHandler: Code: 115. DB::Exception: Setting input_format_with_names_use_headers is neither a builtin setting nor started with the prefix 'SQL_' or 'custom_' registered for user-defined settings: Maybe you meant ['input_format_with_names_use_header','input_format_with_types_use_header']. (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::CustomSettingsPrefixes::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x000000002ecdd208 5. ./build_docker/./src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a07 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002eed10b2 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002fc65045 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002fc6581f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333d18c5 10. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:12:43.219510 [ 1658 ] {e58022dd-6aa3-43dd-baed-6fd454de9fe9} executeQuery: Code: 36. DB::Exception: Cannot turn rows into a ORC format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37402) (comment: 02113_format_row_bug.sql) (in query: select formatRow('ORC', number, toDate(number)) from numbers(5);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b9490fe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:43.219756 [ 1658 ] {e58022dd-6aa3-43dd-baed-6fd454de9fe9} TCPHandler: Code: 36. DB::Exception: Cannot turn rows into a ORC format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b9490fe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:43.222860 [ 1658 ] {0b93bcea-bfef-4423-a9c8-88960d134c0f} executeQuery: Code: 36. DB::Exception: Cannot turn rows into a Parquet format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37402) (comment: 02113_format_row_bug.sql) (in query: select formatRow('Parquet', number, toDate(number)) from numbers(5);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b9490fe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:43.222968 [ 1658 ] {0b93bcea-bfef-4423-a9c8-88960d134c0f} TCPHandler: Code: 36. DB::Exception: Cannot turn rows into a Parquet format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b9490fe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:43.224981 [ 1658 ] {4c65a981-b51c-43a0-8629-450cbc95bcb7} executeQuery: Code: 36. DB::Exception: Cannot turn rows into a Arrow format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37402) (comment: 02113_format_row_bug.sql) (in query: select formatRow('Arrow', number, toDate(number)) from numbers(5);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b9490fe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:43.225087 [ 1658 ] {4c65a981-b51c-43a0-8629-450cbc95bcb7} TCPHandler: Code: 36. DB::Exception: Cannot turn rows into a Arrow format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b9490fe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:43.227987 [ 1658 ] {704e5ae0-7520-416d-a7cd-7f895e6e518b} executeQuery: Code: 36. DB::Exception: Cannot turn rows into a Native format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37402) (comment: 02113_format_row_bug.sql) (in query: select formatRow('Native', number, toDate(number)) from numbers(5);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b9490fe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:43.228132 [ 1658 ] {704e5ae0-7520-416d-a7cd-7f895e6e518b} TCPHandler: Code: 36. DB::Exception: Cannot turn rows into a Native format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b9490fe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:44.176081 [ 10241 ] {2ed86ff2-dc56-4233-99f2-664f8147a326} executeQuery: Code: 475. DB::Exception: Value of step is to low (3600 seconds). Must be >= 1 day. (INVALID_WITH_FILL_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:37466) (comment: 02112_with_fill_interval.sql) (in query: SELECT d, count() FROM with_fill_date GROUP BY d ORDER BY d WITH FILL STEP INTERVAL 1 HOUR LIMIT 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&&) @ 0x00000000321bd9fb 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:145: DB::tryConvertFields(DB::FillColumnDescription&, std::shared_ptr const&) @ 0x0000000033ebf7ee 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:226: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000033ebb366 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], bool const&>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9cac 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9a03 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000033eb8b8f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002f3e3b2e 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f3e38c1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033eb7db8 12. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033edaab5 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:44.176324 [ 10241 ] {2ed86ff2-dc56-4233-99f2-664f8147a326} TCPHandler: Code: 475. DB::Exception: Value of step is to low (3600 seconds). Must be >= 1 day. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&&) @ 0x00000000321bd9fb 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:145: DB::tryConvertFields(DB::FillColumnDescription&, std::shared_ptr const&) @ 0x0000000033ebf7ee 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:226: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000033ebb366 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], bool const&>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9cac 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9a03 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000033eb8b8f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002f3e3b2e 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f3e38c1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033eb7db8 12. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033edaab5 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:44.217061 [ 10241 ] {631b56bf-6264-4d56-bdff-8ad2c459d691} executeQuery: Code: 475. DB::Exception: Value of step is to low (3600 seconds). Must be >= 1 day. (INVALID_WITH_FILL_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:37466) (comment: 02112_with_fill_interval.sql) (in query: SELECT d, count() FROM with_fill_date GROUP BY d ORDER BY d WITH FILL STEP INTERVAL 1 HOUR LIMIT 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&&) @ 0x00000000321bd9fb 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:145: DB::tryConvertFields(DB::FillColumnDescription&, std::shared_ptr const&) @ 0x0000000033ebf7ee 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:226: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000033ebb366 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], bool const&>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9cac 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9a03 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000033eb8b8f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002f3e3b2e 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f3e38c1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033eb7db8 12. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033edaab5 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:44.217255 [ 10241 ] {631b56bf-6264-4d56-bdff-8ad2c459d691} TCPHandler: Code: 475. DB::Exception: Value of step is to low (3600 seconds). Must be >= 1 day. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&&) @ 0x00000000321bd9fb 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:145: DB::tryConvertFields(DB::FillColumnDescription&, std::shared_ptr const&) @ 0x0000000033ebf7ee 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:226: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000033ebb366 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], bool const&>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9cac 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9a03 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000033eb8b8f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002f3e3b2e 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f3e38c1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033eb7db8 12. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033edaab5 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:44.294821 [ 1658 ] {5e27c4a1-3806-47ff-86b8-21ccc45b6139} executeQuery: Code: 628. DB::Exception: Can not use OFFSET FETCH clause without ORDER BY. (OFFSET_FETCH_WITHOUT_ORDER_BY) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:36084) (comment: 02114_offset_fetch_without_order_by.sh) (in query: SELECT number from numbers(10) OFFSET 1 ROWS FETCH FIRST 1 ROWS ONLY;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Parsers/ParserSelectQuery.cpp:0: DB::ParserSelectQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346e3051 5. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 6. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346dd320 7. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 8. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f57f5 9. ./src/Parsers/ExpressionListParsers.h:0: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e4ea7 10. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 11. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346a9d9d 12. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 13. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:76: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003468b483 14. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 15. ./build_docker/./src/Parsers/ParserQuery.cpp:0: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003467d110 16. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 17. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000346f9e4a 18. ./build_docker/./src/Parsers/parseQuery.cpp:366: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc28e 19. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 20. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 23. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 24. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:44.321495 [ 10241 ] {b894a59c-22aa-4f4f-bee8-66b3bc27e8d1} executeQuery: Code: 475. DB::Exception: STEP of Interval type can be used only with Date/DateTime types, but got UInt64. (INVALID_WITH_FILL_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:37466) (comment: 02112_with_fill_interval.sql) (in query: SELECT number FROM numbers(100) ORDER BY number WITH FILL STEP INTERVAL 1 HOUR;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:0: DB::tryConvertFields(DB::FillColumnDescription&, std::shared_ptr const&) @ 0x0000000033ebf987 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:226: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000033ebb366 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], bool const&>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9cac 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9a03 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000033eb8b8f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002f3e3b2e 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f3e38c1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033eb7db8 12. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033edaab5 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:44.321548 [ 1658 ] {5e27c4a1-3806-47ff-86b8-21ccc45b6139} DynamicQueryHandler: Code: 628. DB::Exception: Can not use OFFSET FETCH clause without ORDER BY. (OFFSET_FETCH_WITHOUT_ORDER_BY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Parsers/ParserSelectQuery.cpp:0: DB::ParserSelectQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346e3051 5. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 6. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346dd320 7. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 8. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f57f5 9. ./src/Parsers/ExpressionListParsers.h:0: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e4ea7 10. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 11. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346a9d9d 12. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 13. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:76: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003468b483 14. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 15. ./build_docker/./src/Parsers/ParserQuery.cpp:0: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003467d110 16. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 17. ./build_docker/./src/Parsers/parseQuery.cpp:0: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000346f9e4a 18. ./build_docker/./src/Parsers/parseQuery.cpp:366: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc28e 19. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 20. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 23. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 24. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:12:44.321746 [ 10241 ] {b894a59c-22aa-4f4f-bee8-66b3bc27e8d1} TCPHandler: Code: 475. DB::Exception: STEP of Interval type can be used only with Date/DateTime types, but got UInt64. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:0: DB::tryConvertFields(DB::FillColumnDescription&, std::shared_ptr const&) @ 0x0000000033ebf987 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:226: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000033ebb366 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], bool const&>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9cac 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9a03 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000033eb8b8f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002f3e3b2e 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f3e38c1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033eb7db8 12. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033edaab5 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:44.425839 [ 23590 ] {8287abae-8608-47e6-842a-17de692f1fa1} executeQuery: Code: 36. DB::Exception: Bad hdfs url: abcd. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37480) (comment: 02114_hdfs_bad_url.sh) (in query: SELECT * FROM hdfs('abcd', 'CSV', 'x UInt32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:44.426190 [ 23590 ] {8287abae-8608-47e6-842a-17de692f1fa1} TCPHandler: Code: 36. DB::Exception: Bad hdfs url: abcd. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:44.656128 [ 23590 ] {007e69f4-1427-4b7a-b4da-0cbdaea63e54} executeQuery: Code: 36. DB::Exception: Bad hdfs url: abcd/. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37512) (comment: 02114_hdfs_bad_url.sh) (in query: SELECT * FROM hdfs('abcd/', 'CSV', 'x UInt32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:44.656458 [ 23590 ] {007e69f4-1427-4b7a-b4da-0cbdaea63e54} TCPHandler: Code: 36. DB::Exception: Bad hdfs url: abcd/. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:44.890451 [ 10241 ] {16c19800-9c4c-43e2-8844-9bd50fd918a6} executeQuery: Code: 36. DB::Exception: Bad hdfs url: //abcd. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37540) (comment: 02114_hdfs_bad_url.sh) (in query: SELECT * FROM hdfs('//abcd', 'CSV', 'x UInt32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:44.890765 [ 10241 ] {16c19800-9c4c-43e2-8844-9bd50fd918a6} TCPHandler: Code: 36. DB::Exception: Bad hdfs url: //abcd. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:45.101978 [ 10241 ] {d59c71bf-d905-41ab-9a55-08d7762ee82a} executeQuery: Code: 36. DB::Exception: Bad hdfs url: //abcd/. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37556) (comment: 02114_hdfs_bad_url.sh) (in query: SELECT * FROM hdfs('//abcd/', 'CSV', 'x UInt32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:45.102074 [ 23622 ] {} ServerErrorHandler: Code: 101. DB::NetException: Unexpected packet from client (expected Hello, got 104). (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x00000000334c69bc 4. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497004 5. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 6. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 10. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:12:45.102325 [ 10241 ] {d59c71bf-d905-41ab-9a55-08d7762ee82a} TCPHandler: Code: 36. DB::Exception: Bad hdfs url: //abcd/. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:45.103518 [ 23622 ] {} ServerErrorHandler: Code: 101. DB::NetException: Unexpected packet from client (expected Hello, got 104). (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x00000000334c69bc 4. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497004 5. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 6. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 10. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:12:45.138686 [ 23590 ] {c3696f37-5403-4509-b657-7bff9d8a1e67} executeQuery: Code: 660. DB::Exception: Unable to connect to HDFS: HdfsRpcException: RPC channel to "localhost:9000" got protocol mismatch: RPC channel cannot parse response header. (HDFS_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:37542) (comment: 02113_hdfs_assert.sh) (in query: SELECT * FROM hdfs('hdfs://localhost:9000/data.csv', 'CSV', 'x UInt32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:0: DB::createHDFSFS(hdfsBuilder*) @ 0x000000002ebd5215 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::HDFSSource::URISIterator::Impl::Impl(std::vector> const&, DB::ActionsDAG::Node const*, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x000000002ebc95b7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&>(std::allocator, std::vector> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x000000002ebc8978 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::vector> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&, void>(std::allocator const&, std::vector> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x000000002ebc8712 8. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:597: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList, std::shared_ptr&>(std::allocator, std::vector>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList&&, std::shared_ptr&) @ 0x000000002ebcd3c1 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::vector>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList, std::shared_ptr&, void>(std::allocator const&, std::vector>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList&&, std::shared_ptr&) @ 0x000000002ebcd152 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::ReadFromHDFS::createIterator(DB::ActionsDAG::Node const*) @ 0x000000002ebb5706 11. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:967: DB::ReadFromHDFS::applyFilters(DB::ActionDAGNodes) @ 0x000000002ebb48d1 12. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000003400c97b 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyCondition.cpp:41: DB::QueryPlanOptimizations::optimizePrimaryKeyCondition(std::vector> const&) @ 0x000000003400c5e1 14. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:121: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000034009cf6 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000033f10c66 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f1012e 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:45.139198 [ 23590 ] {c3696f37-5403-4509-b657-7bff9d8a1e67} TCPHandler: Code: 660. DB::Exception: Unable to connect to HDFS: HdfsRpcException: RPC channel to "localhost:9000" got protocol mismatch: RPC channel cannot parse response header. (HDFS_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:0: DB::createHDFSFS(hdfsBuilder*) @ 0x000000002ebd5215 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::HDFSSource::URISIterator::Impl::Impl(std::vector> const&, DB::ActionsDAG::Node const*, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x000000002ebc95b7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&>(std::allocator, std::vector> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x000000002ebc8978 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::vector> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&, void>(std::allocator const&, std::vector> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x000000002ebc8712 8. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:597: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList, std::shared_ptr&>(std::allocator, std::vector>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList&&, std::shared_ptr&) @ 0x000000002ebcd3c1 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::vector>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList, std::shared_ptr&, void>(std::allocator const&, std::vector>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList&&, std::shared_ptr&) @ 0x000000002ebcd152 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::ReadFromHDFS::createIterator(DB::ActionsDAG::Node const*) @ 0x000000002ebb5706 11. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:967: DB::ReadFromHDFS::applyFilters(DB::ActionDAGNodes) @ 0x000000002ebb48d1 12. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000003400c97b 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyCondition.cpp:41: DB::QueryPlanOptimizations::optimizePrimaryKeyCondition(std::vector> const&) @ 0x000000003400c5e1 14. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:121: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000034009cf6 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000033f10c66 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f1012e 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:45.312127 [ 23590 ] {1cb2e5a0-8635-41f5-88e3-ec83a0b27fce} executeQuery: Code: 36. DB::Exception: Bad hdfs url: //abcd/data. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37578) (comment: 02114_hdfs_bad_url.sh) (in query: SELECT * FROM hdfs('//abcd/data', 'CSV', 'x UInt32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:45.312531 [ 23590 ] {1cb2e5a0-8635-41f5-88e3-ec83a0b27fce} TCPHandler: Code: 36. DB::Exception: Bad hdfs url: //abcd/data. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:45.519604 [ 23590 ] {a45900c8-22f8-4c6c-9b1a-b2e2e4eebb35} executeQuery: Code: 36. DB::Exception: Bad hdfs url: ://abcd. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37592) (comment: 02114_hdfs_bad_url.sh) (in query: SELECT * FROM hdfs('://abcd', 'CSV', 'x UInt32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:45.519978 [ 23590 ] {a45900c8-22f8-4c6c-9b1a-b2e2e4eebb35} TCPHandler: Code: 36. DB::Exception: Bad hdfs url: ://abcd. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:45.732019 [ 23590 ] {bf7cd126-51c0-49e0-a28e-1ffcabc18e63} executeQuery: Code: 36. DB::Exception: Bad hdfs url: ://abcd/data. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37604) (comment: 02114_hdfs_bad_url.sh) (in query: SELECT * FROM hdfs('://abcd/data', 'CSV', 'x UInt32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:45.732396 [ 23590 ] {bf7cd126-51c0-49e0-a28e-1ffcabc18e63} TCPHandler: Code: 36. DB::Exception: Bad hdfs url: ://abcd/data. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:45.957932 [ 23590 ] {63bdbf3f-b34c-46bb-a38e-0e039c1be1d0} executeQuery: Code: 36. DB::Exception: Bad hdfs url: abcd:9000. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37620) (comment: 02114_hdfs_bad_url.sh) (in query: SELECT * FROM hdfs('abcd:9000', 'CSV', 'x UInt32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:45.958175 [ 23590 ] {63bdbf3f-b34c-46bb-a38e-0e039c1be1d0} TCPHandler: Code: 36. DB::Exception: Bad hdfs url: abcd:9000. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:46.198140 [ 10241 ] {c0d74ac8-27d9-4f44-a608-3cc567f9ffec} executeQuery: Code: 36. DB::Exception: Bad hdfs url: abcd:9000/data. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37644) (comment: 02114_hdfs_bad_url.sh) (in query: SELECT * FROM hdfs('abcd:9000/data', 'CSV', 'x UInt32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:46.198582 [ 10241 ] {c0d74ac8-27d9-4f44-a608-3cc567f9ffec} TCPHandler: Code: 36. DB::Exception: Bad hdfs url: abcd:9000/data. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:46.414067 [ 10241 ] {c0b52063-1042-45c0-8b6c-b4eb8be726e2} executeQuery: Code: 36. DB::Exception: Bad hdfs url: //abcd:9000/data. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37680) (comment: 02114_hdfs_bad_url.sh) (in query: SELECT * FROM hdfs('//abcd:9000/data', 'CSV', 'x UInt32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:46.414347 [ 10241 ] {c0b52063-1042-45c0-8b6c-b4eb8be726e2} TCPHandler: Code: 36. DB::Exception: Bad hdfs url: //abcd:9000/data. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:46.628340 [ 23590 ] {d5ad486c-4065-46a7-b470-485dd3b8697a} executeQuery: Code: 36. DB::Exception: Bad hdfs url: ://abcd:9000/data. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37696) (comment: 02114_hdfs_bad_url.sh) (in query: SELECT * FROM hdfs('://abcd:9000/data', 'CSV', 'x UInt32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:46.628635 [ 23590 ] {d5ad486c-4065-46a7-b470-485dd3b8697a} TCPHandler: Code: 36. DB::Exception: Bad hdfs url: ://abcd:9000/data. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:46.836896 [ 10241 ] {4829f73d-1434-4a56-b35b-1fcaba382b96} executeQuery: Code: 36. DB::Exception: Bad hdfs url: abcd/. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37728) (comment: 02114_hdfs_bad_url.sh) (in query: SELECT * FROM hdfs('abcd/', 'CSV', 'x UInt32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:46.837233 [ 10241 ] {4829f73d-1434-4a56-b35b-1fcaba382b96} TCPHandler: Code: 36. DB::Exception: Bad hdfs url: abcd/. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:47.071064 [ 10241 ] {2a4f9b02-bc16-4b92-9536-f225c0cbe6ce} executeQuery: Code: 36. DB::Exception: Bad hdfs url: hdfs://abcd. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37744) (comment: 02114_hdfs_bad_url.sh) (in query: SELECT * FROM hdfs('hdfs://abcd', 'CSV', 'x UInt32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:47.071378 [ 10241 ] {2a4f9b02-bc16-4b92-9536-f225c0cbe6ce} TCPHandler: Code: 36. DB::Exception: Bad hdfs url: hdfs://abcd. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:47.273061 [ 12525 ] {0529aa6e-b8e5-4374-b40a-438c0c3c06b4} executeQuery: Code: 36. DB::Exception: Bad hdfs url: hdfs1:9000/data. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37796) (comment: 02114_hdfs_bad_url.sh) (in query: SELECT * FROM hdfs('hdfs1:9000/data', 'CSV', 'x UInt32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:47.273296 [ 12525 ] {0529aa6e-b8e5-4374-b40a-438c0c3c06b4} TCPHandler: Code: 36. DB::Exception: Bad hdfs url: hdfs1:9000/data. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:47.488587 [ 10241 ] {7ed8d14d-cca8-4084-a655-191bb4993ffa} executeQuery: Code: 660. DB::Exception: Unable to connect to HDFS: InvalidParameter: Cannot parse URI: hdfs://hdfs1, missing port or invalid HA configuration Caused by: HdfsConfigNotFound: Config key: dfs.ha.namenodes.hdfs1 not found. (HDFS_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:37824) (comment: 02114_hdfs_bad_url.sh) (in query: SELECT * FROM hdfs('hdfs://hdfs1/data', 'CSV', 'x UInt32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:0: DB::createHDFSFS(hdfsBuilder*) @ 0x000000002ebd5215 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::HDFSSource::URISIterator::Impl::Impl(std::vector> const&, DB::ActionsDAG::Node const*, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x000000002ebc95b7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&>(std::allocator, std::vector> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x000000002ebc8978 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::vector> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&, void>(std::allocator const&, std::vector> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x000000002ebc8712 8. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:597: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList, std::shared_ptr&>(std::allocator, std::vector>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList&&, std::shared_ptr&) @ 0x000000002ebcd3c1 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::vector>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList, std::shared_ptr&, void>(std::allocator const&, std::vector>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList&&, std::shared_ptr&) @ 0x000000002ebcd152 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::ReadFromHDFS::createIterator(DB::ActionsDAG::Node const*) @ 0x000000002ebb5706 11. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:967: DB::ReadFromHDFS::applyFilters(DB::ActionDAGNodes) @ 0x000000002ebb48d1 12. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000003400c97b 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyCondition.cpp:41: DB::QueryPlanOptimizations::optimizePrimaryKeyCondition(std::vector> const&) @ 0x000000003400c5e1 14. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:121: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000034009cf6 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000033f10c66 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f1012e 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:47.488974 [ 10241 ] {7ed8d14d-cca8-4084-a655-191bb4993ffa} TCPHandler: Code: 660. DB::Exception: Unable to connect to HDFS: InvalidParameter: Cannot parse URI: hdfs://hdfs1, missing port or invalid HA configuration Caused by: HdfsConfigNotFound: Config key: dfs.ha.namenodes.hdfs1 not found. (HDFS_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:0: DB::createHDFSFS(hdfsBuilder*) @ 0x000000002ebd5215 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::HDFSSource::URISIterator::Impl::Impl(std::vector> const&, DB::ActionsDAG::Node const*, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x000000002ebc95b7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&>(std::allocator, std::vector> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x000000002ebc8978 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::vector> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&, void>(std::allocator const&, std::vector> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x000000002ebc8712 8. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:597: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList, std::shared_ptr&>(std::allocator, std::vector>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList&&, std::shared_ptr&) @ 0x000000002ebcd3c1 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::vector>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList, std::shared_ptr&, void>(std::allocator const&, std::vector>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList&&, std::shared_ptr&) @ 0x000000002ebcd152 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::ReadFromHDFS::createIterator(DB::ActionsDAG::Node const*) @ 0x000000002ebb5706 11. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:967: DB::ReadFromHDFS::applyFilters(DB::ActionDAGNodes) @ 0x000000002ebb48d1 12. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000003400c97b 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyCondition.cpp:41: DB::QueryPlanOptimizations::optimizePrimaryKeyCondition(std::vector> const&) @ 0x000000003400c5e1 14. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:121: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000034009cf6 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000033f10c66 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f1012e 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:47.691919 [ 10241 ] {86cfa2ec-165a-4914-a4a2-4597289193dc} executeQuery: Code: 36. DB::Exception: Bad hdfs url: http://hdfs1:9000/data. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37858) (comment: 02114_hdfs_bad_url.sh) (in query: SELECT * FROM hdfs('http://hdfs1:9000/data', 'CSV', 'x UInt32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:47.692282 [ 10241 ] {86cfa2ec-165a-4914-a4a2-4597289193dc} TCPHandler: Code: 36. DB::Exception: Bad hdfs url: http://hdfs1:9000/data. It should have structure 'hdfs://:/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4ca294 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&) @ 0x000000002e4c9faf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionHDFS::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e4c9109 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 11. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:47.916486 [ 23597 ] {5de43828-fc18-421f-ac8e-65481112a0f5} executeQuery: Code: 660. DB::Exception: Unable to connect to HDFS: InvalidParameter: Cannot parse URI: hdfs://nameservice, missing port or invalid HA configuration Caused by: HdfsConfigNotFound: Config key: dfs.ha.namenodes.nameservice not found. (HDFS_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:37894) (comment: 02114_hdfs_bad_url.sh) (in query: SELECT * FROM hdfs('hdfs://hdfs1@nameservice/abcd/data', 'CSV', 'x UInt32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:0: DB::createHDFSFS(hdfsBuilder*) @ 0x000000002ebd5215 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::HDFSSource::URISIterator::Impl::Impl(std::vector> const&, DB::ActionsDAG::Node const*, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x000000002ebc95b7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&>(std::allocator, std::vector> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x000000002ebc8978 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::vector> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&, void>(std::allocator const&, std::vector> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x000000002ebc8712 8. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:597: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList, std::shared_ptr&>(std::allocator, std::vector>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList&&, std::shared_ptr&) @ 0x000000002ebcd3c1 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::vector>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList, std::shared_ptr&, void>(std::allocator const&, std::vector>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList&&, std::shared_ptr&) @ 0x000000002ebcd152 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::ReadFromHDFS::createIterator(DB::ActionsDAG::Node const*) @ 0x000000002ebb5706 11. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:967: DB::ReadFromHDFS::applyFilters(DB::ActionDAGNodes) @ 0x000000002ebb48d1 12. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000003400c97b 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyCondition.cpp:41: DB::QueryPlanOptimizations::optimizePrimaryKeyCondition(std::vector> const&) @ 0x000000003400c5e1 14. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:121: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000034009cf6 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000033f10c66 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f1012e 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:47.916873 [ 23597 ] {5de43828-fc18-421f-ac8e-65481112a0f5} TCPHandler: Code: 660. DB::Exception: Unable to connect to HDFS: InvalidParameter: Cannot parse URI: hdfs://nameservice, missing port or invalid HA configuration Caused by: HdfsConfigNotFound: Config key: dfs.ha.namenodes.nameservice not found. (HDFS_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:0: DB::createHDFSFS(hdfsBuilder*) @ 0x000000002ebd5215 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::HDFSSource::URISIterator::Impl::Impl(std::vector> const&, DB::ActionsDAG::Node const*, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x000000002ebc95b7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&>(std::allocator, std::vector> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x000000002ebc8978 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::vector> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&, void>(std::allocator const&, std::vector> const&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList const&, std::shared_ptr const&) @ 0x000000002ebc8712 8. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:597: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList, std::shared_ptr&>(std::allocator, std::vector>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList&&, std::shared_ptr&) @ 0x000000002ebcd3c1 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::vector>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList, std::shared_ptr&, void>(std::allocator const&, std::vector>&, DB::ActionsDAG::Node const*&, DB::NamesAndTypesList&&, std::shared_ptr&) @ 0x000000002ebcd152 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::ReadFromHDFS::createIterator(DB::ActionsDAG::Node const*) @ 0x000000002ebb5706 11. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:967: DB::ReadFromHDFS::applyFilters(DB::ActionDAGNodes) @ 0x000000002ebb48d1 12. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000003400c97b 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyCondition.cpp:41: DB::QueryPlanOptimizations::optimizePrimaryKeyCondition(std::vector> const&) @ 0x000000003400c5e1 14. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:121: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000034009cf6 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000033f10c66 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f1012e 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:51.193229 [ 14920 ] {47986e9d-a3a6-406b-9e96-72abd8305276} executeQuery: Code: 80. DB::Exception: There are no columns in sampling expression. (INCORRECT_QUERY) (version 24.3.12.76.altinitystable) (from [::1]:53348) (comment: 02096_sample_by_tuple.sql) (in query: CREATE TABLE t (`n` UInt8) ENGINE = MergeTree ORDER BY n SAMPLE BY tuple() SETTINGS index_granularity = 21259, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.35002779960632324, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 144364348, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25997646, merge_max_block_size = 8343, old_parts_lifetime = 243., prefer_fetch_merged_part_size_threshold = 1812967133, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7562299857, index_granularity_bytes = 7157665, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 49118, primary_key_compress_block_size = 47148), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x0000000032ae91bd 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:410: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5b3a 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 8. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 10. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:51.193452 [ 14920 ] {47986e9d-a3a6-406b-9e96-72abd8305276} TCPHandler: Code: 80. DB::Exception: There are no columns in sampling expression. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x0000000032ae91bd 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:410: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5b3a 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 8. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 10. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:51.215477 [ 14920 ] {5dee0a22-6b4f-496e-ada9-8206d3c4222f} executeQuery: Code: 80. DB::Exception: There are no columns in sampling expression. (INCORRECT_QUERY) (version 24.3.12.76.altinitystable) (from [::1]:53348) (comment: 02096_sample_by_tuple.sql) (in query: ALTER TABLE t MODIFY SAMPLE BY tuple();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x0000000032ae91bd 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3f61a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:51.215712 [ 14920 ] {5dee0a22-6b4f-496e-ada9-8206d3c4222f} TCPHandler: Code: 80. DB::Exception: There are no columns in sampling expression. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x0000000032ae91bd 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3f61a 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:54.960180 [ 23577 ] {a4c02d76-bc68-40e2-9365-7902991784d0} executeQuery: Code: 6. DB::Exception: Cannot parse string 'f' as Int32: syntax error at begin of string. Note: there are toInt32OrZero and toInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while converting source column `'f'` to destination column s. (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:53910) (comment: 02047_client_exception.expect) (in query: INSERT INTO test_02047 SELECT 'f'), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018362975 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001835a22f 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 17. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 19. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002fb5de8b 21. ./build_docker/./src/Interpreters/ActionsDAG.cpp:244: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002fb5d0e3 22. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1455: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000002fb717d6 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:597: DB::InterpreterInsertQuery::execute() @ 0x0000000030f39095 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:12:54.960566 [ 23577 ] {a4c02d76-bc68-40e2-9365-7902991784d0} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'f' as Int32: syntax error at begin of string. Note: there are toInt32OrZero and toInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while converting source column `'f'` to destination column s. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018362975 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001835a22f 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 17. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 19. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002fb5de8b 21. ./build_docker/./src/Interpreters/ActionsDAG.cpp:244: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002fb5d0e3 22. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1455: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000002fb717d6 23. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:597: DB::InterpreterInsertQuery::execute() @ 0x0000000030f39095 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:12:56.084982 [ 23635 ] {f6f55f7e-9f1c-4e0d-9d4f-c2b7b300659a} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Tuple(Date, String), Tuple(String)) of function equals: In scope SELECT * FROM test_tuple_filter WHERE (log_date, value) = tuple('2021-01-01'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:53980) (comment: 02030_tuple_filter.sql) (in query: SELECT * FROM test_tuple_filter WHERE (log_date, value) = tuple('2021-01-01');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b186fc4 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:56.085110 [ 23635 ] {f6f55f7e-9f1c-4e0d-9d4f-c2b7b300659a} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Tuple(Date, String), Tuple(String)) of function equals: In scope SELECT * FROM test_tuple_filter WHERE (log_date, value) = tuple('2021-01-01'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b186fc4 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:56.086886 [ 23635 ] {ada44f45-4bc2-43f2-972b-096491c51c3a} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Tuple(UInt32, String), Tuple(UInt8)) of function equals: In scope SELECT * FROM test_tuple_filter WHERE (id, value) = tuple(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:53980) (comment: 02030_tuple_filter.sql) (in query: SELECT * FROM test_tuple_filter WHERE (id, value) = tuple(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b186fc4 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:56.087038 [ 23635 ] {ada44f45-4bc2-43f2-972b-096491c51c3a} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Tuple(UInt32, String), Tuple(UInt8)) of function equals: In scope SELECT * FROM test_tuple_filter WHERE (id, value) = tuple(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001b186fc4 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:56.121609 [ 23635 ] {a14d6f0d-904f-4878-9eec-13ceb7e090c4} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt32, String because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:53980) (comment: 02030_tuple_filter.sql) (in query: SELECT * FROM test_tuple_filter WHERE tuple(id, value) = tuple(value, id);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001b1a5b4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b184411 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:56.121856 [ 23635 ] {a14d6f0d-904f-4878-9eec-13ceb7e090c4} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt32, String because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001b1a5b4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b184411 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 18. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:56.144955 [ 23635 ] {53a300fd-6a87-4669-82dc-7943a6e039f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 1, should be 2: In scope SELECT * FROM test_tuple_filter WHERE equals((id, value)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:53980) (comment: 02030_tuple_filter.sql) (in query: SELECT * FROM test_tuple_filter WHERE equals((id, value));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:56.145161 [ 23635 ] {53a300fd-6a87-4669-82dc-7943a6e039f1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 1, should be 2: In scope SELECT * FROM test_tuple_filter WHERE equals((id, value)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:12:57.726178 [ 22865 ] {} HTTPServerRequest: Got an HTTP request with no content length and no chunked/multipart encoding, it may be impossible to distinguish graceful EOF from abnormal connection loss 2025.03.05 21:12:57.733732 [ 22865 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:12:57.733921 [ 22865 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:12:58.309506 [ 22865 ] {3d1c1c0b-4560-47e2-a02a-d242859b06a7} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 1.26 MiB (attempt to allocate chunk of 1316616 bytes), maximum: 1.00 B.: In scope SELECT range(10000) AS b_arr. (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:54154) (comment: 02028_create_select_settings.sql) (in query: CREATE TABLE test_table ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 51296, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.07744065672159195, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 220520311, compact_parts_max_bytes_to_buffer = 481759491, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 14042613, merge_max_block_size = 5778, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 89, min_merge_bytes_to_use_direct_io = 213073833, index_granularity_bytes = 5192585, concurrent_part_removal_threshold = 87, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 74010, primary_key_compress_block_size = 84648 AS SELECT a_table.a, b_table.b_arr FROM (SELECT arrayJoin(range(10000)) AS a) AS a_table CROSS JOIN (SELECT range(10000) AS b_arr) AS b_table SETTINGS max_memory_usage = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. AllocatorWithMemoryTracking::allocate(unsigned long) @ 0x0000000018107446 8. ./contrib/llvm-project/libcxx/include/__split_buffer:0: std::vector>::reserve(unsigned long) @ 0x000000002e5ee0a2 9. ./build_docker/./src/Columns/ColumnArray.cpp:147: DB::ColumnArray::get(unsigned long, DB::Field&) const @ 0x00000000319441b0 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b2a99 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6519: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882639 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7911: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd42 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7732: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dc28f 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000030fffe75 25. ./contrib/llvm-project/libcxx/include/vector:951: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b7940 26. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 27. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:12:58.309760 [ 22865 ] {3d1c1c0b-4560-47e2-a02a-d242859b06a7} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 1.26 MiB (attempt to allocate chunk of 1316616 bytes), maximum: 1.00 B.: In scope SELECT range(10000) AS b_arr. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. AllocatorWithMemoryTracking::allocate(unsigned long) @ 0x0000000018107446 8. ./contrib/llvm-project/libcxx/include/__split_buffer:0: std::vector>::reserve(unsigned long) @ 0x000000002e5ee0a2 9. ./build_docker/./src/Columns/ColumnArray.cpp:147: DB::ColumnArray::get(unsigned long, DB::Field&) const @ 0x00000000319441b0 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b2a99 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6519: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882639 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7911: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd42 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7732: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dc28f 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000030fffe75 25. ./contrib/llvm-project/libcxx/include/vector:951: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b7940 26. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 27. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:13:00.170480 [ 3522 ] {d6c4b2b0-e0b1-44d0-a1d7-cc24b1dc140e} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.3.12.76.altinitystable) (from [::1]:43806) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:00.170599 [ 3522 ] {d6c4b2b0-e0b1-44d0-a1d7-cc24b1dc140e} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:00.439901 [ 23582 ] {f5762e22-e5ad-4379-a0c1-986dfb05ba17} executeQuery: Code: 475. DB::Exception: Multiple WITH FILL for identical expressions is not supported in ORDER BY. (INVALID_WITH_FILL_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:43836) (comment: 02018_multiple_with_fill_for_the_same_column.sql) (in query: SELECT x, y FROM (SELECT 5 AS x, 'Hello' AS y) ORDER BY x WITH FILL FROM 3 TO 7, y, x WITH FILL FROM 1 TO 10;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:0: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000033ebbef2 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], bool const&>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9cac 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9a03 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000033eb8b8f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002f3e3b2e 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f3e38c1 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033eb7db8 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033edaab5 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:00.440212 [ 23582 ] {f5762e22-e5ad-4379-a0c1-986dfb05ba17} TCPHandler: Code: 475. DB::Exception: Multiple WITH FILL for identical expressions is not supported in ORDER BY. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:0: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000033ebbef2 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], bool const&>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9cac 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9a03 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000033eb8b8f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002f3e3b2e 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f3e38c1 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033eb7db8 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033edaab5 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:03.600343 [ 6285 ] {350650e2-ae17-40a7-b62e-5974b8cfe796} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_asbpqjqv.async_inserts (0e9ad5b1-bf27-45f4-b683-1e3ebf91f90d)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 02015_async_inserts_5.sh) (in query: INSERT INTO test_asbpqjqv.async_inserts FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000032bee462 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000032b6f0db 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51656 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002fc02b29 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002fc06b2b 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:03.600570 [ 6285 ] {} AsynchronousInsertQueue: Failed insertion for query 'INSERT INTO test_asbpqjqv.async_inserts FORMAT JSONEachRow': Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_asbpqjqv.async_inserts (0e9ad5b1-bf27-45f4-b683-1e3ebf91f90d)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000032bee462 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000032b6f0db 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51656 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002fc02b29 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002fc06b2b 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:03.600969 [ 23582 ] {3662de97-3d3d-4ca2-ad13-2e079d4f443f} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_asbpqjqv.async_inserts (0e9ad5b1-bf27-45f4-b683-1e3ebf91f90d)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:52868) (comment: 02015_async_inserts_5.sh) (in query: INSERT INTO async_inserts FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000032bee462 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000032b6f0db 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51656 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002fc02b29 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002fc06b2b 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:03.600974 [ 3522 ] {d50deaf5-91a6-49ea-8cc5-f3e91428d03d} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_asbpqjqv.async_inserts (0e9ad5b1-bf27-45f4-b683-1e3ebf91f90d)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:52852) (comment: 02015_async_inserts_5.sh) (in query: INSERT INTO async_inserts FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000032bee462 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000032b6f0db 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51656 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002fc02b29 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002fc06b2b 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:03.601053 [ 23606 ] {95d07611-132d-46ef-89af-b211d1eef9ed} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_asbpqjqv.async_inserts (0e9ad5b1-bf27-45f4-b683-1e3ebf91f90d)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:52872) (comment: 02015_async_inserts_5.sh) (in query: INSERT INTO async_inserts FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000032bee462 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000032b6f0db 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51656 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002fc02b29 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002fc06b2b 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:03.601164 [ 23582 ] {3662de97-3d3d-4ca2-ad13-2e079d4f443f} DynamicQueryHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_asbpqjqv.async_inserts (0e9ad5b1-bf27-45f4-b683-1e3ebf91f90d)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000032bee462 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000032b6f0db 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51656 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002fc02b29 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002fc06b2b 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:03.601267 [ 3522 ] {d50deaf5-91a6-49ea-8cc5-f3e91428d03d} DynamicQueryHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_asbpqjqv.async_inserts (0e9ad5b1-bf27-45f4-b683-1e3ebf91f90d)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000032bee462 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000032b6f0db 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51656 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002fc02b29 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002fc06b2b 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:03.601298 [ 23606 ] {95d07611-132d-46ef-89af-b211d1eef9ed} DynamicQueryHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_asbpqjqv.async_inserts (0e9ad5b1-bf27-45f4-b683-1e3ebf91f90d)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000032bee462 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000032b6f0db 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51656 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002fc02b29 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002fc06b2b 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:04.979493 [ 23612 ] {9bba159b-4128-4773-a72c-eafe9472ec3d} executeQuery: Code: 60. DB::Exception: Table test_dy5c2qo3.async_inserts1 does not exist. Maybe you meant test_dy5c2qo3.async_inserts?. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:32962) (comment: 02015_async_inserts_6.sh) (in query: INSERT INTO async_inserts1 FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fbf6ec7 9. ./contrib/llvm-project/libcxx/include/string:1624: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002fbf75eb 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1053: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fa3cd 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:04.979776 [ 23612 ] {9bba159b-4128-4773-a72c-eafe9472ec3d} DynamicQueryHandler: Code: 60. DB::Exception: Table test_dy5c2qo3.async_inserts1 does not exist. Maybe you meant test_dy5c2qo3.async_inserts?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fbf6ec7 9. ./contrib/llvm-project/libcxx/include/string:1624: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002fbf75eb 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1053: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fa3cd 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:05.014733 [ 22858 ] {bb806923-e9e4-40e8-a3c6-b5ce431ab81e} executeQuery: Code: 73. DB::Exception: Unknown input format BadFormat. (UNKNOWN_FORMAT) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:33582) (comment: 02015_async_inserts_6.sh) (in query: INSERT INTO async_inserts FORMAT BadFormat ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:309: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fbf7337 5. ./contrib/llvm-project/libcxx/include/string:1624: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002fbf75eb 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1053: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fa3cd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:05.014994 [ 22858 ] {bb806923-e9e4-40e8-a3c6-b5ce431ab81e} DynamicQueryHandler: Code: 73. DB::Exception: Unknown input format BadFormat. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:309: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fbf7337 5. ./contrib/llvm-project/libcxx/include/string:1624: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002fbf75eb 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1053: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fa3cd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:05.023337 [ 23622 ] {6a9973bf-58e3-4a99-acbb-334eb8ac0636} executeQuery: Code: 73. DB::Exception: Unknown input format Pretty. (UNKNOWN_FORMAT) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:33954) (comment: 02015_async_inserts_6.sh) (in query: INSERT INTO async_inserts FORMAT Pretty ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:309: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fbf7337 5. ./contrib/llvm-project/libcxx/include/string:1624: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002fbf75eb 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1053: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fa3cd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:05.023515 [ 23622 ] {6a9973bf-58e3-4a99-acbb-334eb8ac0636} DynamicQueryHandler: Code: 73. DB::Exception: Unknown input format Pretty. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:309: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fbf7337 5. ./contrib/llvm-project/libcxx/include/string:1624: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002fbf75eb 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1053: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fa3cd 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:05.048013 [ 23601 ] {17014a0d-d5dd-4ae5-b68d-74d7b8bf0127} executeQuery: Code: 16. DB::Exception: No such column a in table test_dy5c2qo3.async_inserts (8d193f5e-2090-4d61-baf4-6ad8af2701bc). (NO_SUCH_COLUMN_IN_TABLE) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:34062) (comment: 02015_async_inserts_6.sh) (in query: INSERT INTO async_inserts (id, a) FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x0000000030f3215d 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x0000000030f31559 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:306: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fbf701b 7. ./contrib/llvm-project/libcxx/include/string:1624: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002fbf75eb 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1053: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fa3cd 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:05.048283 [ 23601 ] {17014a0d-d5dd-4ae5-b68d-74d7b8bf0127} DynamicQueryHandler: Code: 16. DB::Exception: No such column a in table test_dy5c2qo3.async_inserts (8d193f5e-2090-4d61-baf4-6ad8af2701bc). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x0000000030f3215d 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x0000000030f31559 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:306: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fbf701b 7. ./contrib/llvm-project/libcxx/include/string:1624: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002fbf75eb 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1053: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fa3cd 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:05.518556 [ 1658 ] {13159e93-de0b-4598-9089-fb9e0124e1e9} executeQuery: Code: 701. DB::Exception: There is no port named unknown: In scope SELECT getServerPort('unknown'). (CLUSTER_DOESNT_EXIST) (version 24.3.12.76.altinitystable) (from [::1]:44434) (comment: 02012_get_server_port.sql) (in query: select getServerPort('unknown');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/Context.cpp:3672: DB::Context::getServerPort(String const&) const @ 0x000000002fc7c46a 5. DB::(anonymous namespace)::GetServerPortOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000001bb11803 6. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844964 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:05.518705 [ 1658 ] {13159e93-de0b-4598-9089-fb9e0124e1e9} TCPHandler: Code: 701. DB::Exception: There is no port named unknown: In scope SELECT getServerPort('unknown'). (CLUSTER_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/Context.cpp:3672: DB::Context::getServerPort(String const&) const @ 0x000000002fc7c46a 5. DB::(anonymous namespace)::GetServerPortOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000001bb11803 6. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844964 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:08.254113 [ 14974 ] {ae92e15d-20cd-4132-ade0-56f7b74035f4} executeQuery: Code: 43. DB::Exception: The argument tuple for function tupleToNameValuePairs must contain just one type.: In scope SELECT tupleToNameValuePairs((1, 1.3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:45280) (comment: 02008_tuple_to_name_value_pairs.sql) (in query: SELECT tupleToNameValuePairs(tuple(1, 1.3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021c6bb64 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:08.254312 [ 14974 ] {ae92e15d-20cd-4132-ade0-56f7b74035f4} TCPHandler: Code: 43. DB::Exception: The argument tuple for function tupleToNameValuePairs must contain just one type.: In scope SELECT tupleToNameValuePairs((1, 1.3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021c6bb64 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:08.268083 [ 14974 ] {4dcaf949-5484-4cc9-b9f6-51e50ff7872e} executeQuery: Code: 43. DB::Exception: The argument tuple for function tupleToNameValuePairs must contain just one type.: In scope SELECT tupleToNameValuePairs((1, [1, 2])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:45280) (comment: 02008_tuple_to_name_value_pairs.sql) (in query: SELECT tupleToNameValuePairs(tuple(1, [1,2]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021c6bb64 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:08.268284 [ 14974 ] {4dcaf949-5484-4cc9-b9f6-51e50ff7872e} TCPHandler: Code: 43. DB::Exception: The argument tuple for function tupleToNameValuePairs must contain just one type.: In scope SELECT tupleToNameValuePairs((1, [1, 2])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021c6bb64 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:08.277415 [ 14974 ] {b44d6ccb-b7d3-4dc0-af58-0d581bd898b7} executeQuery: Code: 43. DB::Exception: The argument tuple for function tupleToNameValuePairs must contain just one type.: In scope SELECT tupleToNameValuePairs((1, 'a')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:45280) (comment: 02008_tuple_to_name_value_pairs.sql) (in query: SELECT tupleToNameValuePairs(tuple(1, 'a'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021c6bb64 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:08.277571 [ 14974 ] {b44d6ccb-b7d3-4dc0-af58-0d581bd898b7} TCPHandler: Code: 43. DB::Exception: The argument tuple for function tupleToNameValuePairs must contain just one type.: In scope SELECT tupleToNameValuePairs((1, 'a')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021c6bb64 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:08.328981 [ 14974 ] {cb041918-b1ac-4a2e-9a7a-58061cf06529} executeQuery: Code: 43. DB::Exception: First argument for function tupleToNameValuePairs must be a tuple.: In scope SELECT tupleToNameValuePairs(33). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:45280) (comment: 02008_tuple_to_name_value_pairs.sql) (in query: SELECT tupleToNameValuePairs(33);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021c6bc8d 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:08.329234 [ 14974 ] {cb041918-b1ac-4a2e-9a7a-58061cf06529} TCPHandler: Code: 43. DB::Exception: First argument for function tupleToNameValuePairs must be a tuple.: In scope SELECT tupleToNameValuePairs(33). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021c6bc8d 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:08.842379 [ 34946 ] {a03ada8e-8cd9-4e1f-a4d1-d1f4a4585b33} executeQuery: Code: 78. DB::Exception: Query has infile and was send directly to server. (UNKNOWN_TYPE_OF_QUERY) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:37974) (comment: 02009_from_infile.sh) (in query: INSERT INTO test_infile_url FROM INFILE '/tmp/clickhouse-test/0_stateless/test_q34fmvpk/test_infile.gz' FORMAT CSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Processors/Transforms/getSourceFromASTInsertQuery.cpp:44: DB::getInputFormatFromASTInsertQuery(std::shared_ptr const&, bool, DB::Block const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000033cb48fc 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:708: DB::InterpreterInsertQuery::execute() @ 0x0000000030f3a763 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:08.842649 [ 34946 ] {a03ada8e-8cd9-4e1f-a4d1-d1f4a4585b33} DynamicQueryHandler: Code: 78. DB::Exception: Query has infile and was send directly to server. (UNKNOWN_TYPE_OF_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Processors/Transforms/getSourceFromASTInsertQuery.cpp:44: DB::getInputFormatFromASTInsertQuery(std::shared_ptr const&, bool, DB::Block const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000033cb48fc 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:708: DB::InterpreterInsertQuery::execute() @ 0x0000000030f3a763 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:09.528156 [ 22860 ] {43f26ad2-6a7e-49db-af7b-4902a2e96402} executeQuery: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 24.3.12.76.altinitystable) (from [::1]:40496) (comment: 02006_test_positional_arguments.sql) (in query: select max(x1), x2 from test group by 1, 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030943593 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000030943817 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093adbe 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:09.528416 [ 22860 ] {43f26ad2-6a7e-49db-af7b-4902a2e96402} TCPHandler: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030943593 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000030943817 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093adbe 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:09.565783 [ 22860 ] {ea84aa35-273d-40ea-b4b9-6889ff1c7115} executeQuery: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 24.3.12.76.altinitystable) (from [::1]:40496) (comment: 02006_test_positional_arguments.sql) (in query: select 1 + max(x1), x2 from test group by 1, 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030943593 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000030943817 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093adbe 10. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:09.565997 [ 22860 ] {ea84aa35-273d-40ea-b4b9-6889ff1c7115} TCPHandler: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030943593 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000030943817 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093adbe 10. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:09.580710 [ 22860 ] {5a282cd0-2484-4852-a315-fe5f54a8ac22} executeQuery: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 24.3.12.76.altinitystable) (from [::1]:40496) (comment: 02006_test_positional_arguments.sql) (in query: select max(x1), x2 from test group by -2, -1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030943593 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000030943817 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093adbe 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:09.580878 [ 22860 ] {5a282cd0-2484-4852-a315-fe5f54a8ac22} TCPHandler: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030943593 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000030943817 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093adbe 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:09.583546 [ 22860 ] {8b475383-a536-48b5-9b20-9e0832ac0d3a} executeQuery: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 24.3.12.76.altinitystable) (from [::1]:40496) (comment: 02006_test_positional_arguments.sql) (in query: select 1 + max(x1), x2 from test group by -2, -1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030943593 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000030943817 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093adbe 10. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:09.583678 [ 22860 ] {8b475383-a536-48b5-9b20-9e0832ac0d3a} TCPHandler: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030943593 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000030943817 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093adbe 10. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:11.614555 [ 48605 ] {7f5d3471-4a7b-4d17-926c-f9ba1c69ba95} executeQuery: Code: 248. DB::Exception: Invalid partition format: NO_SUCH_PART. (INVALID_PARTITION_VALUE) (version 24.3.12.76.altinitystable) (from [::1]:41330) (comment: 02004_invalid_partition_mutation_stuck.sql) (in query: ALTER TABLE rep_data MATERIALIZE INDEX idx IN PARTITION ID 'NO_SUCH_PART';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:50: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x0000000032d7ec2f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000032b46fcc 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::getPartitionIdsAffectedByCommands(DB::MutationCommands const&, std::shared_ptr) const @ 0x0000000032b90dff 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5971: DB::StorageReplicatedMergeTree::allocateBlockNumbersInAffectedPartitions(DB::MutationCommands const&, std::shared_ptr, std::shared_ptr const&) const @ 0x00000000324a164f 8. ./contrib/llvm-project/libcxx/include/__tree:1124: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000324e589f 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:11.614867 [ 48605 ] {7f5d3471-4a7b-4d17-926c-f9ba1c69ba95} TCPHandler: Code: 248. DB::Exception: Invalid partition format: NO_SUCH_PART. (INVALID_PARTITION_VALUE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:50: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x0000000032d7ec2f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000032b46fcc 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::getPartitionIdsAffectedByCommands(DB::MutationCommands const&, std::shared_ptr) const @ 0x0000000032b90dff 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5971: DB::StorageReplicatedMergeTree::allocateBlockNumbersInAffectedPartitions(DB::MutationCommands const&, std::shared_ptr, std::shared_ptr const&) const @ 0x00000000324a164f 8. ./contrib/llvm-project/libcxx/include/__tree:1124: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000324e589f 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:11.702629 [ 48605 ] {cdb2b41b-4a07-4ce9-a3a0-1116cab976d1} executeQuery: Code: 248. DB::Exception: Invalid partition format: NO_SUCH_PART. (INVALID_PARTITION_VALUE) (version 24.3.12.76.altinitystable) (from [::1]:41330) (comment: 02004_invalid_partition_mutation_stuck.sql) (in query: ALTER TABLE data MATERIALIZE INDEX idx IN PARTITION ID 'NO_SUCH_PART';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:50: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x0000000032d7ec2f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000032b46fcc 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::getPartitionIdsAffectedByCommands(DB::MutationCommands const&, std::shared_ptr) const @ 0x0000000032b90dff 7. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d2b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:11.702775 [ 48605 ] {cdb2b41b-4a07-4ce9-a3a0-1116cab976d1} TCPHandler: Code: 248. DB::Exception: Invalid partition format: NO_SUCH_PART. (INVALID_PARTITION_VALUE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:50: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x0000000032d7ec2f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000032b46fcc 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::getPartitionIdsAffectedByCommands(DB::MutationCommands const&, std::shared_ptr) const @ 0x0000000032b90dff 7. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d2b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:12.522610 [ 23586 ] {34d24dab-f256-4ce1-aa49-8acd19de8ab0} executeQuery: Code: 36. DB::Exception: Element of set in IN, VALUES, or LIMIT, or aggregate function parameter, or a table function argument is not a constant expression (result column not found): globalIn(tuple(_CAST(NULL, 'Nullable(Nothing)'), _CAST(NULL, 'Nullable(Nothing)'), 0), some_identifier). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:41762) (comment: 02002_global_subqueries_subquery_or_table_name.sql) (in query: SELECT cityHash64(number GLOBAL IN (NULL, -2147483648, -9223372036854775808), nan, 1024, NULL, NULL, 1.000100016593933, NULL), (NULL, cityHash64(inf, -2147483648, NULL, NULL, 10.000100135803223), cityHash64(1.1754943508222875e-38, NULL, NULL, NULL), 2147483647) FROM cluster(test_cluster_two_shards_localhost, numbers((NULL, cityHash64(0., 65536, NULL, NULL, 10000000000., NULL), 0) GLOBAL IN (some_identifier), 65536)) WHERE number GLOBAL IN [1025] --{serverError 36, 284} ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:0: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x00000000316be701 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316bf2e4 6. ./contrib/llvm-project/libcxx/include/__utility/pair.h:513: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x000000002e441db0 7. ./contrib/abseil-cpp/absl/container/internal/inlined_vector.h:383: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4411df 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 9. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 11. ./contrib/llvm-project/libcxx/include/vector:1562: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030886bca 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:12.522895 [ 23586 ] {34d24dab-f256-4ce1-aa49-8acd19de8ab0} TCPHandler: Code: 36. DB::Exception: Element of set in IN, VALUES, or LIMIT, or aggregate function parameter, or a table function argument is not a constant expression (result column not found): globalIn(tuple(_CAST(NULL, 'Nullable(Nothing)'), _CAST(NULL, 'Nullable(Nothing)'), 0), some_identifier). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:0: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x00000000316be701 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000316bf2e4 6. ./contrib/llvm-project/libcxx/include/__utility/pair.h:513: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x000000002e441db0 7. ./contrib/abseil-cpp/absl/container/internal/inlined_vector.h:383: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4411df 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 9. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 11. ./contrib/llvm-project/libcxx/include/vector:1562: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030886bca 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.312694 [ 23610 ] {cef41e7d-2fa4-441d-9c60-796cac8bb41d} executeQuery: Code: 403. DB::Exception: JOIN test_ve2recw9.t1 AS __table1 ALL INNER JOIN test_ve2recw9.t2 AS __table2 ON _CAST(1, 'UInt16') cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: SELECT * FROM t1 JOIN t2 ON toUInt16(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.312943 [ 23610 ] {cef41e7d-2fa4-441d-9c60-796cac8bb41d} TCPHandler: Code: 403. DB::Exception: JOIN test_ve2recw9.t1 AS __table1 ALL INNER JOIN test_ve2recw9.t2 AS __table2 ON _CAST(1, 'UInt16') cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.315824 [ 23610 ] {8e5dc5ee-dcb9-4540-8b82-aaa50e5b3692} executeQuery: Code: 403. DB::Exception: JOIN test_ve2recw9.t1 AS __table1 ALL INNER JOIN test_ve2recw9.t2 AS __table2 ON _CAST(1, 'Int8') cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: SELECT * FROM t1 JOIN t2 ON toInt8(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.316527 [ 23610 ] {8e5dc5ee-dcb9-4540-8b82-aaa50e5b3692} TCPHandler: Code: 403. DB::Exception: JOIN test_ve2recw9.t1 AS __table1 ALL INNER JOIN test_ve2recw9.t2 AS __table2 ON _CAST(1, 'Int8') cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.319271 [ 23610 ] {51bd587b-0306-401b-8dc6-ff27f4da2927} executeQuery: Code: 403. DB::Exception: JOIN test_ve2recw9.t1 AS __table1 ALL INNER JOIN test_ve2recw9.t2 AS __table2 ON 256 join expression expected function. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: SELECT * FROM t1 JOIN t2 ON 256;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000031097587 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.319418 [ 23610 ] {51bd587b-0306-401b-8dc6-ff27f4da2927} TCPHandler: Code: 403. DB::Exception: JOIN test_ve2recw9.t1 AS __table1 ALL INNER JOIN test_ve2recw9.t2 AS __table2 ON 256 join expression expected function. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000031097587 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.321460 [ 23610 ] {3b580290-4aad-416b-ab3c-c934b06de418} executeQuery: Code: 403. DB::Exception: JOIN test_ve2recw9.t1 AS __table1 ALL INNER JOIN test_ve2recw9.t2 AS __table2 ON -1 join expression expected function. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: SELECT * FROM t1 JOIN t2 ON -1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000031097587 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.321576 [ 23610 ] {3b580290-4aad-416b-ab3c-c934b06de418} TCPHandler: Code: 403. DB::Exception: JOIN test_ve2recw9.t1 AS __table1 ALL INNER JOIN test_ve2recw9.t2 AS __table2 ON -1 join expression expected function. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000031097587 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.323800 [ 23610 ] {317e332b-aba8-41e2-8b07-400aea13edd7} executeQuery: Code: 403. DB::Exception: JOIN test_ve2recw9.t1 AS __table1 ALL INNER JOIN test_ve2recw9.t2 AS __table2 ON _CAST('1', 'String') cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: SELECT * FROM t1 JOIN t2 ON toString(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.323905 [ 23610 ] {317e332b-aba8-41e2-8b07-400aea13edd7} TCPHandler: Code: 403. DB::Exception: JOIN test_ve2recw9.t1 AS __table1 ALL INNER JOIN test_ve2recw9.t2 AS __table2 ON _CAST('1', 'String') cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.401514 [ 23610 ] {662fde5e-e52f-4f7b-8483-907bfb4cbc6e} executeQuery: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: -- in this cases in old analuyzer we have AMBIGUOUS_COLUMN_NAME instead of INVALID_JOIN_ON_EXPRESSION -- because there's some function in ON expression is not constant itself (result is constant) SELECT * FROM t1 JOIN t2 ON 1 = 1 SETTINGS join_algorithm = 'full_sorting_merge';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109ad61 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.401705 [ 23610 ] {662fde5e-e52f-4f7b-8483-907bfb4cbc6e} TCPHandler: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109ad61 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.404668 [ 23610 ] {9dba9bb0-0181-4989-b61e-38d20591ba1a} executeQuery: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: SELECT * FROM t1 JOIN t2 ON 1 = 1 SETTINGS join_algorithm = 'partial_merge';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109ad61 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.404770 [ 23610 ] {9dba9bb0-0181-4989-b61e-38d20591ba1a} TCPHandler: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109ad61 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.406737 [ 23610 ] {5ea2db9e-1629-451b-985b-705412f097e0} executeQuery: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: SELECT * FROM t1 JOIN t2 ON 1 = 1 SETTINGS join_algorithm = 'auto';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109ad61 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.406827 [ 23610 ] {5ea2db9e-1629-451b-985b-705412f097e0} TCPHandler: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109ad61 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.408407 [ 23610 ] {7a7f6487-1a03-42a6-8127-ce3be6e91866} executeQuery: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: SELECT * FROM t1 JOIN t2 ON NULL SETTINGS join_algorithm = 'full_sorting_merge';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109ad61 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.408495 [ 23610 ] {7a7f6487-1a03-42a6-8127-ce3be6e91866} TCPHandler: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109ad61 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.410079 [ 23610 ] {3c720162-923c-444d-859f-e4606b7d18f2} executeQuery: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: SELECT * FROM t1 JOIN t2 ON NULL SETTINGS join_algorithm = 'partial_merge';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109ad61 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.410170 [ 23610 ] {3c720162-923c-444d-859f-e4606b7d18f2} TCPHandler: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109ad61 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.411705 [ 23610 ] {9b73591a-7cda-4371-8324-bdc1d33240ae} executeQuery: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: SELECT * FROM t1 LEFT JOIN t2 ON NULL SETTINGS join_algorithm = 'partial_merge';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109ad61 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.411799 [ 23610 ] {9b73591a-7cda-4371-8324-bdc1d33240ae} TCPHandler: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109ad61 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.413398 [ 23610 ] {e29d9954-ebe7-466f-a45f-a836f9d0fcd4} executeQuery: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: SELECT * FROM t1 RIGHT JOIN t2 ON NULL SETTINGS join_algorithm = 'auto';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109ad61 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.413488 [ 23610 ] {e29d9954-ebe7-466f-a45f-a836f9d0fcd4} TCPHandler: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109ad61 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.414977 [ 23610 ] {284c97b2-72a4-4abb-86be-3121918ab477} executeQuery: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: SELECT * FROM t1 FULL JOIN t2 ON NULL SETTINGS join_algorithm = 'partial_merge';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109ad61 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.415100 [ 23610 ] {284c97b2-72a4-4abb-86be-3121918ab477} TCPHandler: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109ad61 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.445518 [ 23610 ] {35c9a06c-319a-4cae-8d68-42d7660372ba} executeQuery: Code: 352. DB::Exception: Ambiguous columns in expression '1 = 1' in JOIN ON section: While processing 1 = 1. (AMBIGUOUS_COLUMN_NAME) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: -- mixing of constant and non-constant expressions in ON is not allowed SELECT * FROM t1 JOIN t2 ON t1.id = t2.id AND 1 == 1 SETTINGS allow_experimental_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:0: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003165243c 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000315d60cd 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d68f5 7. ./src/Interpreters/InDepthNodeVisitor.h:83: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d690a 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::collectJoinedColumns(DB::TableJoin&, DB::ASTTableJoin&, std::vector> const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr) @ 0x00000000315c2d77 9. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x00000000315bd821 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f5eb42 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.445747 [ 23610 ] {35c9a06c-319a-4cae-8d68-42d7660372ba} TCPHandler: Code: 352. DB::Exception: Ambiguous columns in expression '1 = 1' in JOIN ON section: While processing 1 = 1. (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:0: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003165243c 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000315d60cd 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d68f5 7. ./src/Interpreters/InDepthNodeVisitor.h:83: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d690a 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::collectJoinedColumns(DB::TableJoin&, DB::ASTTableJoin&, std::vector> const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr) @ 0x00000000315c2d77 9. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x00000000315bd821 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f5eb42 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.452483 [ 23610 ] {59f3f6d8-755f-4d12-9646-b84de043fa83} executeQuery: Code: 352. DB::Exception: Ambiguous columns in expression '1 = 2' in JOIN ON section: While processing 1 = 2. (AMBIGUOUS_COLUMN_NAME) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: SELECT * FROM t1 JOIN t2 ON t1.id = t2.id AND 1 == 2 SETTINGS allow_experimental_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:0: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003165243c 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000315d60cd 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d68f5 7. ./src/Interpreters/InDepthNodeVisitor.h:83: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d690a 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::collectJoinedColumns(DB::TableJoin&, DB::ASTTableJoin&, std::vector> const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr) @ 0x00000000315c2d77 9. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x00000000315bd821 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f5eb42 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.452594 [ 23610 ] {59f3f6d8-755f-4d12-9646-b84de043fa83} TCPHandler: Code: 352. DB::Exception: Ambiguous columns in expression '1 = 2' in JOIN ON section: While processing 1 = 2. (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:0: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003165243c 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000315d60cd 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d68f5 7. ./src/Interpreters/InDepthNodeVisitor.h:83: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d690a 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::collectJoinedColumns(DB::TableJoin&, DB::ASTTableJoin&, std::vector> const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr) @ 0x00000000315c2d77 9. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x00000000315bd821 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f5eb42 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.480599 [ 23610 ] {d4ded499-3d77-4144-83db-a353dd89b0bb} executeQuery: Code: 403. DB::Exception: Unsupported JOIN ON conditions. Unexpected '1 != 1': While processing 1 != 1. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: SELECT * FROM t1 JOIN t2 ON t1.id = t2.id AND 1 != 1 SETTINGS allow_experimental_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:0: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003165213c 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000315d60cd 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d68f5 7. ./src/Interpreters/InDepthNodeVisitor.h:83: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d690a 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::collectJoinedColumns(DB::TableJoin&, DB::ASTTableJoin&, std::vector> const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr) @ 0x00000000315c2d77 9. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x00000000315bd821 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f5eb42 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.480856 [ 23610 ] {d4ded499-3d77-4144-83db-a353dd89b0bb} TCPHandler: Code: 403. DB::Exception: Unsupported JOIN ON conditions. Unexpected '1 != 1': While processing 1 != 1. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:0: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x000000003165213c 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000315d60cd 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d68f5 7. ./src/Interpreters/InDepthNodeVisitor.h:83: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d690a 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::collectJoinedColumns(DB::TableJoin&, DB::ASTTableJoin&, std::vector> const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr) @ 0x00000000315c2d77 9. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x00000000315bd821 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f5eb42 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.515487 [ 23610 ] {ab889d97-cb9f-49c4-b9a7-fe015c217e5a} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)' of type 'Nothing'. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: SELECT * FROM t1 JOIN t2 ON t1.id = t2.id AND NULL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:0: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x00000000310f391b 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x00000000303f8c2f 6. ./contrib/llvm-project/libcxx/include/string:843: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000033b5e26a 7. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x0000000033ef2899 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x0000000033ef045c 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1455: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106d192 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.515730 [ 23610 ] {ab889d97-cb9f-49c4-b9a7-fe015c217e5a} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)' of type 'Nothing'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:0: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x00000000310f391b 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x00000000303f8c2f 6. ./contrib/llvm-project/libcxx/include/string:843: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000033b5e26a 7. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x0000000033ef2899 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x0000000033ef045c 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1455: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106d192 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.518066 [ 23610 ] {b8b48701-a1db-4d65-ace3-7e81e5bce954} executeQuery: Code: 43. DB::Exception: Illegal type (String) of 2 argument of function and: In scope SELECT * FROM t1 INNER JOIN t2 ON (t1.id = t2.id) AND 'aaa'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: SELECT * FROM t1 JOIN t2 ON t1.id = t2.id AND 'aaa';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000018082175 4. ./build_docker/./src/Functions/FunctionsLogical.cpp:0: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002e8c050b 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dcf56 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.518191 [ 23610 ] {b8b48701-a1db-4d65-ace3-7e81e5bce954} TCPHandler: Code: 43. DB::Exception: Illegal type (String) of 2 argument of function and: In scope SELECT * FROM t1 INNER JOIN t2 ON (t1.id = t2.id) AND 'aaa'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000018082175 4. ./build_docker/./src/Functions/FunctionsLogical.cpp:0: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002e8c050b 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dcf56 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.519770 [ 23610 ] {212e54e2-544a-4396-a9e0-9a5614a399f5} executeQuery: Code: 403. DB::Exception: JOIN test_ve2recw9.t1 AS __table1 ALL INNER JOIN test_ve2recw9.t2 AS __table2 ON 'aaa' join expression expected function. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: SELECT * FROM t1 JOIN t2 ON 'aaa';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000031097587 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.519861 [ 23610 ] {212e54e2-544a-4396-a9e0-9a5614a399f5} TCPHandler: Code: 403. DB::Exception: JOIN test_ve2recw9.t1 AS __table1 ALL INNER JOIN test_ve2recw9.t2 AS __table2 ON 'aaa' join expression expected function. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000031097587 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.545959 [ 23610 ] {c6c0a71e-3f95-41f5-83e1-da6841608041} executeQuery: Code: 403. DB::Exception: Illegal expression '0' in JOIN ON section: While processing 0. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: SELECT * FROM t1 JOIN t2 ON t1.id = t2.id AND 0 SETTINGS allow_experimental_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:0: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000315d6588 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000315d60cd 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d68f5 7. ./src/Interpreters/InDepthNodeVisitor.h:83: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d690a 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::collectJoinedColumns(DB::TableJoin&, DB::ASTTableJoin&, std::vector> const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr) @ 0x00000000315c2d77 9. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x00000000315bd821 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f5eb42 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.546236 [ 23610 ] {c6c0a71e-3f95-41f5-83e1-da6841608041} TCPHandler: Code: 403. DB::Exception: Illegal expression '0' in JOIN ON section: While processing 0. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:0: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000315d6588 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000315d60cd 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d68f5 7. ./src/Interpreters/InDepthNodeVisitor.h:83: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d690a 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::collectJoinedColumns(DB::TableJoin&, DB::ASTTableJoin&, std::vector> const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr) @ 0x00000000315c2d77 9. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x00000000315bd821 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f5eb42 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.553809 [ 23610 ] {d2965d1f-7901-4f68-874a-66274332290e} executeQuery: Code: 403. DB::Exception: Illegal expression '1' in JOIN ON section: While processing 1. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:42416) (comment: 02000_join_on_const.sql) (in query: SELECT * FROM t1 JOIN t2 ON t1.id = t2.id AND 1 SETTINGS allow_experimental_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:0: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000315d6588 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000315d60cd 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d68f5 7. ./src/Interpreters/InDepthNodeVisitor.h:83: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d690a 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::collectJoinedColumns(DB::TableJoin&, DB::ASTTableJoin&, std::vector> const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr) @ 0x00000000315c2d77 9. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x00000000315bd821 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f5eb42 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.554674 [ 23610 ] {d2965d1f-7901-4f68-874a-66274332290e} TCPHandler: Code: 403. DB::Exception: Illegal expression '1' in JOIN ON section: While processing 1. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./src/Interpreters/CollectJoinOnKeysVisitor.h:0: DB::CollectJoinOnKeysMatcher::visit(std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000315d6588 5. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000315d60cd 6. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d68f5 7. ./src/Interpreters/InDepthNodeVisitor.h:83: void DB::InDepthNodeVisitor const>::visitChildren(std::shared_ptr const&) @ 0x00000000315d690a 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::collectJoinedColumns(DB::TableJoin&, DB::ASTTableJoin&, std::vector> const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr) @ 0x00000000315c2d77 9. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x00000000315bd821 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f5eb42 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.927871 [ 14974 ] {c3374892-4384-4e8f-aa5d-e76f1c272d69} executeQuery: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 1 UInt8 Const(size = 0, UInt8(size = 1)) 1 Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (AMBIGUOUS_COLUMN_NAME) (version 24.3.12.76.altinitystable) (from [::1]:42772) (comment: 01950_aliases_bad_cast.sql) (in query: SELECT 1, * FROM (SELECT NULL AS `1`);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002f119af1 4. ./build_docker/./src/Core/Block.cpp:38: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000002f10a4e6 5. ./contrib/llvm-project/libcxx/include/vector:1595: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000002f10b124 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65ee9 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 9. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000031013b4f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.927979 [ 14974 ] {c3374892-4384-4e8f-aa5d-e76f1c272d69} TCPHandler: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 1 UInt8 Const(size = 0, UInt8(size = 1)) 1 Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002f119af1 4. ./build_docker/./src/Core/Block.cpp:38: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000002f10a4e6 5. ./contrib/llvm-project/libcxx/include/vector:1595: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000002f10b124 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65ee9 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 9. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000031013b4f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.930080 [ 14974 ] {2ee4bace-8830-4aac-b03d-109c87b00e7e} executeQuery: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 'xyz' String Const(size = 0, String(size = 1)) 'xyz' Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (AMBIGUOUS_COLUMN_NAME) (version 24.3.12.76.altinitystable) (from [::1]:42772) (comment: 01950_aliases_bad_cast.sql) (in query: SELECT '7', 'xyz', * FROM (SELECT NULL AS `'xyz'`);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002f119af1 4. ./build_docker/./src/Core/Block.cpp:38: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000002f10a4e6 5. ./contrib/llvm-project/libcxx/include/vector:1595: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000002f10b124 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65ee9 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 9. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000031013b4f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:14.930175 [ 14974 ] {2ee4bace-8830-4aac-b03d-109c87b00e7e} TCPHandler: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 'xyz' String Const(size = 0, String(size = 1)) 'xyz' Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002f119af1 4. ./build_docker/./src/Core/Block.cpp:38: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000002f10a4e6 5. ./contrib/llvm-project/libcxx/include/vector:1595: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000002f10b124 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65ee9 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 9. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000031013b4f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:15.736891 [ 6285 ] {5b543aba-9121-4c38-a2e0-4a9ed3ceb25c} executeQuery: Code: 60. DB::Exception: Table test_nprnbmu9.async_inserts (c277f9b7-57d1-4087-8f27-1ea9800aec83) does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 02015_async_inserts_stress_long.sh) (in query: INSERT INTO test_nprnbmu9.async_inserts FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./contrib/llvm-project/libcxx/include/optional:897: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd8543f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:790: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002fbffaa1 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002fc06b2b 10. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 11. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:15.737086 [ 6285 ] {} AsynchronousInsertQueue: Failed insertion for query 'INSERT INTO test_nprnbmu9.async_inserts FORMAT JSONEachRow': Code: 60. DB::Exception: Table test_nprnbmu9.async_inserts (c277f9b7-57d1-4087-8f27-1ea9800aec83) does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./contrib/llvm-project/libcxx/include/optional:897: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd8543f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:790: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002fbffaa1 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002fc06b2b 10. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 11. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:15.790700 [ 730 ] {0dc4acff-1157-4e62-996c-f83f363301aa} executeQuery: Code: 69. DB::Exception: A call to function range would produce 12 array elements, which is greater than the allowed maximum of 10: while executing 'FUNCTION range(modulo(__table1.number, 3_UInt8) :: 0) -> range(modulo(__table1.number, 3_UInt8)) Array(UInt8) : 1'. (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:43116) (comment: 01944_range_max_elements.sql) (in query: SELECT range(number % 3) FROM numbers(12);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. COW::immutable_ptr DB::FunctionRange::executeInternal(DB::IColumn const*) const @ 0x00000000245af16b 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000245a9c8f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:15.790852 [ 730 ] {0dc4acff-1157-4e62-996c-f83f363301aa} TCPHandler: Code: 69. DB::Exception: A call to function range would produce 12 array elements, which is greater than the allowed maximum of 10: while executing 'FUNCTION range(modulo(__table1.number, 3_UInt8) :: 0) -> range(modulo(__table1.number, 3_UInt8)) Array(UInt8) : 1'. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. COW::immutable_ptr DB::FunctionRange::executeInternal(DB::IColumn const*) const @ 0x00000000245af16b 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000245a9c8f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:16.140172 [ 730 ] {71dc5379-cc15-4ffe-8d15-418400bc68bf} executeQuery: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `greater(now(), toDateTime('2020-06-01 13:31:40'))`: for Sorting key. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:43296) (comment: 01943_non_deterministic_order_key.sql) (in query: CREATE TABLE a (`number` UInt64) ENGINE = MergeTree ORDER BY if(now() > toDateTime('2020-06-01 13:31:40'), toInt64(number), -number) SETTINGS index_granularity = 2307, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 242541518, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 23947405, merge_max_block_size = 11100, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 7574334224, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3911801989, index_granularity_bytes = 28887878, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 34686, primary_key_compress_block_size = 98382), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1325: DB::ActionsDAG::assertDeterministic() const @ 0x000000002fb70181 5. ./contrib/llvm-project/libcxx/include/vector:1429: DB::checkKeyExpression(DB::ExpressionActions const&, DB::Block const&, String const&, bool) @ 0x0000000032af265e 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af1aa8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 13. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:16.144018 [ 730 ] {71dc5379-cc15-4ffe-8d15-418400bc68bf} TCPHandler: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `greater(now(), toDateTime('2020-06-01 13:31:40'))`: for Sorting key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1325: DB::ActionsDAG::assertDeterministic() const @ 0x000000002fb70181 5. ./contrib/llvm-project/libcxx/include/vector:1429: DB::checkKeyExpression(DB::ExpressionActions const&, DB::Block const&, String const&, bool) @ 0x0000000032af265e 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af1aa8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 13. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:16.148527 [ 730 ] {815ad120-300d-4021-a2e0-3ace674a6f0f} executeQuery: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `now()`: for Sorting key. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:43296) (comment: 01943_non_deterministic_order_key.sql) (in query: CREATE TABLE b (`number` UInt64) ENGINE = MergeTree ORDER BY now() > toDateTime(number) SETTINGS index_granularity = 2307, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 242541518, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 23947405, merge_max_block_size = 11100, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 7574334224, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3911801989, index_granularity_bytes = 28887878, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 34686, primary_key_compress_block_size = 98382), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1325: DB::ActionsDAG::assertDeterministic() const @ 0x000000002fb70181 5. ./contrib/llvm-project/libcxx/include/vector:1429: DB::checkKeyExpression(DB::ExpressionActions const&, DB::Block const&, String const&, bool) @ 0x0000000032af265e 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af1aa8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 13. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:16.148703 [ 730 ] {815ad120-300d-4021-a2e0-3ace674a6f0f} TCPHandler: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `now()`: for Sorting key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1325: DB::ActionsDAG::assertDeterministic() const @ 0x000000002fb70181 5. ./contrib/llvm-project/libcxx/include/vector:1429: DB::checkKeyExpression(DB::ExpressionActions const&, DB::Block const&, String const&, bool) @ 0x0000000032af265e 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af1aa8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 13. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:16.151160 [ 730 ] {f89e0d3e-9be2-4e0b-8655-544091c646ec} executeQuery: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `now()`: for Sorting key. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:43296) (comment: 01943_non_deterministic_order_key.sql) (in query: CREATE TABLE c (`number` UInt64) ENGINE = MergeTree ORDER BY now() SETTINGS index_granularity = 2307, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 242541518, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 23947405, merge_max_block_size = 11100, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 7574334224, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3911801989, index_granularity_bytes = 28887878, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 34686, primary_key_compress_block_size = 98382), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1325: DB::ActionsDAG::assertDeterministic() const @ 0x000000002fb70181 5. ./contrib/llvm-project/libcxx/include/vector:1429: DB::checkKeyExpression(DB::ExpressionActions const&, DB::Block const&, String const&, bool) @ 0x0000000032af265e 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af1aa8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 13. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:16.151292 [ 730 ] {f89e0d3e-9be2-4e0b-8655-544091c646ec} TCPHandler: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `now()`: for Sorting key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1325: DB::ActionsDAG::assertDeterministic() const @ 0x000000002fb70181 5. ./contrib/llvm-project/libcxx/include/vector:1429: DB::checkKeyExpression(DB::ExpressionActions const&, DB::Block const&, String const&, bool) @ 0x0000000032af265e 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x0000000032af1aa8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000032ae7e0c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:401: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a33 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 13. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:17.242782 [ 14920 ] {880cfd6a-3b26-47c4-a571-376e692cc6e7} executeQuery: Code: 59. DB::Exception: Invalid sampling column type in storage parameters: UUID. Must be one unsigned integer type. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.3.12.76.altinitystable) (from [::1]:43846) (comment: 01942_create_table_with_sample.sql) (in query: CREATE TABLE IF NOT EXISTS sample_incorrect (`x` UUID) ENGINE = MergeTree ORDER BY tuple(x) SAMPLE BY x SETTINGS index_granularity = 60162, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 382958109, compact_parts_max_granules_to_buffer = 78, compact_parts_merge_max_bytes_to_prefetch_part = 2536346, merge_max_block_size = 10936, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 52, min_merge_bytes_to_use_direct_io = 4243503429, index_granularity_bytes = 5109398, concurrent_part_removal_threshold = 43, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 14093, primary_key_compress_block_size = 62038), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x0000000032ae9324 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:410: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5b3a 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 8. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 10. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:17.243126 [ 14920 ] {880cfd6a-3b26-47c4-a571-376e692cc6e7} TCPHandler: Code: 59. DB::Exception: Invalid sampling column type in storage parameters: UUID. Must be one unsigned integer type. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x0000000032ae9324 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:410: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5b3a 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 8. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 10. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:17.532612 [ 14920 ] {d891d633-888b-411f-bbc7-5d63a6eb74cb} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for function snowflakeToDateTime provided 0, expected 1 to 2 ('value' : Int64, ['time_zone' : String]): In scope SELECT snowflakeToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:43944) (comment: 01942_snowflakeToDateTime.sql) (in query: -- -- Error cases SELECT snowflakeToDateTime();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::(anonymous namespace)::FunctionSnowflakeToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021628b9f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:17.532852 [ 14920 ] {d891d633-888b-411f-bbc7-5d63a6eb74cb} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for function snowflakeToDateTime provided 0, expected 1 to 2 ('value' : Int64, ['time_zone' : String]): In scope SELECT snowflakeToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::(anonymous namespace)::FunctionSnowflakeToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021628b9f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:17.558546 [ 14920 ] {cf300d28-488b-4256-b2c9-ebd28e6fb867} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for function snowflakeToDateTime64 provided 0, expected 1 to 2 ('value' : Int64, ['time_zone' : String]): In scope SELECT snowflakeToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:43944) (comment: 01942_snowflakeToDateTime.sql) (in query: SELECT snowflakeToDateTime64();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::(anonymous namespace)::FunctionSnowflakeToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000002162a1bf 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:17.558747 [ 14920 ] {cf300d28-488b-4256-b2c9-ebd28e6fb867} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for function snowflakeToDateTime64 provided 0, expected 1 to 2 ('value' : Int64, ['time_zone' : String]): In scope SELECT snowflakeToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::(anonymous namespace)::FunctionSnowflakeToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000002162a1bf 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:17.586075 [ 14920 ] {7cf20edc-9759-40f5-b05b-71e43405b0b0} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'value' of function snowflakeToDateTime, expected Int64, got String: In scope SELECT snowflakeToDateTime('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:43944) (comment: 01942_snowflakeToDateTime.sql) (in query: SELECT snowflakeToDateTime('abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021628b9f 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:17.586305 [ 14920 ] {7cf20edc-9759-40f5-b05b-71e43405b0b0} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'value' of function snowflakeToDateTime, expected Int64, got String: In scope SELECT snowflakeToDateTime('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021628b9f 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:17.610751 [ 14920 ] {bcefd372-df04-4f52-9687-7ee1ae4e35e3} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'value' of function snowflakeToDateTime64, expected Int64, got String: In scope SELECT snowflakeToDateTime64('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:43944) (comment: 01942_snowflakeToDateTime.sql) (in query: SELECT snowflakeToDateTime64('abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000002162a1bf 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:17.610966 [ 14920 ] {bcefd372-df04-4f52-9687-7ee1ae4e35e3} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'value' of function snowflakeToDateTime64, expected Int64, got String: In scope SELECT snowflakeToDateTime64('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000002162a1bf 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:17.612845 [ 14920 ] {b7abf410-6ea6-43d4-a272-2b9bcd7cf4bf} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'value' of function snowflakeToDateTime, expected Int64, got String: In scope SELECT snowflakeToDateTime('abc', 123). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:43944) (comment: 01942_snowflakeToDateTime.sql) (in query: SELECT snowflakeToDateTime('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021628b9f 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:17.612953 [ 14920 ] {b7abf410-6ea6-43d4-a272-2b9bcd7cf4bf} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'value' of function snowflakeToDateTime, expected Int64, got String: In scope SELECT snowflakeToDateTime('abc', 123). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021628b9f 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:17.614271 [ 14920 ] {03cb7060-a836-424b-8c89-fa2c31e0ab75} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'value' of function snowflakeToDateTime64, expected Int64, got String: In scope SELECT snowflakeToDateTime64('abc', 123). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:43944) (comment: 01942_snowflakeToDateTime.sql) (in query: SELECT snowflakeToDateTime64('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000002162a1bf 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:17.614375 [ 14920 ] {03cb7060-a836-424b-8c89-fa2c31e0ab75} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'value' of function snowflakeToDateTime64, expected Int64, got String: In scope SELECT snowflakeToDateTime64('abc', 123). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000002162a1bf 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:18.624095 [ 22858 ] {e05d251b-7353-491a-bd6d-c823ec4483dc} executeQuery: Code: 703. DB::Exception: Expected dictGet function first argument identifier to contain 1 or 2 parts. Actual 't.nest.a'. In scope SELECT dictGet(t.nest.a, concat(currentDatabase(), '.dict.dict'), 's', number) FROM numbers(5). (INVALID_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:44562) (comment: 01936_three_parts_identifiers_in_wrong_places.sql) (in query: SELECT dictGet(t.nest.a, concat(currentDatabase(), '.dict.dict'), 's', number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String const&, String&&) @ 0x000000002469a523 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308aa1f5 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:18.624298 [ 22858 ] {e05d251b-7353-491a-bd6d-c823ec4483dc} TCPHandler: Code: 703. DB::Exception: Expected dictGet function first argument identifier to contain 1 or 2 parts. Actual 't.nest.a'. In scope SELECT dictGet(t.nest.a, concat(currentDatabase(), '.dict.dict'), 's', number) FROM numbers(5). (INVALID_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String const&, String&&) @ 0x000000002469a523 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308aa1f5 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:18.626527 [ 22858 ] {55461fee-f714-4d9b-905b-e72de49397f6} executeQuery: Code: 703. DB::Exception: Expected dictGetFloat64 function first argument identifier to contain 1 or 2 parts. Actual 't.b.s'. In scope SELECT dictGetFloat64(t.b.s, 'database_for_dict.dict1', dictGetFloat64('Ta\0', toUInt64('databas\0_for_dict.dict1databas\0_for_dict.dict1', dictGetFloat64('', '', toUInt64(1048577), toDate(NULL)), NULL), toDate(dictGetFloat64(257, 'database_for_dict.dict1database_for_dict.dict1', '', toUInt64(NULL), 2, toDate(NULL)), '2019-05-2\0')), NULL, toUInt64(dictGetFloat64('', '', toUInt64(-9223372036854775808), toDate(NULL)), NULL)). (INVALID_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:44562) (comment: 01936_three_parts_identifiers_in_wrong_places.sql) (in query: SELECT dictGetFloat64(t.b.s, 'database_for_dict.dict1', dictGetFloat64('Ta\0', toUInt64('databas\0_for_dict.dict1databas\0_for_dict.dict1', dictGetFloat64('', '', toUInt64(1048577), toDate(NULL)), NULL), toDate(dictGetFloat64(257, 'database_for_dict.dict1database_for_dict.dict1', '', toUInt64(NULL), 2, toDate(NULL)), '2019-05-2\0')), NULL, toUInt64(dictGetFloat64('', '', toUInt64(-9223372036854775808), toDate(NULL)), NULL));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String const&, String&&) @ 0x000000002469a523 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308aa1f5 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:18.626654 [ 22858 ] {55461fee-f714-4d9b-905b-e72de49397f6} TCPHandler: Code: 703. DB::Exception: Expected dictGetFloat64 function first argument identifier to contain 1 or 2 parts. Actual 't.b.s'. In scope SELECT dictGetFloat64(t.b.s, 'database_for_dict.dict1', dictGetFloat64('Ta\0', toUInt64('databas\0_for_dict.dict1databas\0_for_dict.dict1', dictGetFloat64('', '', toUInt64(1048577), toDate(NULL)), NULL), toDate(dictGetFloat64(257, 'database_for_dict.dict1database_for_dict.dict1', '', toUInt64(NULL), 2, toDate(NULL)), '2019-05-2\0')), NULL, toUInt64(dictGetFloat64('', '', toUInt64(-9223372036854775808), toDate(NULL)), NULL)). (INVALID_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String const&, String&&) @ 0x000000002469a523 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308aa1f5 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:18.663579 [ 22858 ] {f8d12294-bcfd-412c-8c7d-99c44d9a4d7b} executeQuery: Code: 703. DB::Exception: Expected identifier 'test_01103.t1_distr.id' to contain 1 or 2 parts to be resolved as table expression. In scope system.one. (INVALID_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:44562) (comment: 01936_three_parts_identifiers_in_wrong_places.sql) (in query: SELECT NULL AND (2147483648 AND NULL) AND -2147483647, toUUID(((1048576 AND NULL) AND (2147483647 AND 257 AND NULL AND -2147483649) AND NULL) IN (test_01103.t1_distr.id), '00000000-e1fe-11e\0-bb8f\0853d60c00749'), stringToH3('89184926cc3ffff89184926cc3ffff89184926cc3ffff89184926cc3ffff89184926cc3ffff89184926cc3ffff89184926cc3ffff89184926cc3ffff');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c851b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883bb5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:13:18.663949 [ 22858 ] {f8d12294-bcfd-412c-8c7d-99c44d9a4d7b} TCPHandler: Code: 703. DB::Exception: Expected identifier 'test_01103.t1_distr.id' to contain 1 or 2 parts to be resolved as table expression. In scope system.one. (INVALID_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c851b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883bb5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:13:18.711749 [ 23606 ] {b6148a87-4ae3-49ee-8078-c1412505b02d} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44612) (comment: 01934_constexpr_aggregate_function_parameters.sql) (in query: SELECT groupArray(NULL)(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000256e4540 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:18.711951 [ 23606 ] {b6148a87-4ae3-49ee-8078-c1412505b02d} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000256e4540 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:18.715308 [ 23606 ] {07ea9929-8e0b-483d-9c12-26987b29bc78} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44612) (comment: 01934_constexpr_aggregate_function_parameters.sql) (in query: SELECT groupArray(NULL + NULL)(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000256e4540 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:18.715525 [ 23606 ] {07ea9929-8e0b-483d-9c12-26987b29bc78} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000256e4540 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:18.718082 [ 23606 ] {d755e9da-bba0-48fb-af02-5d87ddeaee3a} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44612) (comment: 01934_constexpr_aggregate_function_parameters.sql) (in query: SELECT groupArray([])(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000256e4540 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:18.718305 [ 23606 ] {d755e9da-bba0-48fb-af02-5d87ddeaee3a} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000256e4540 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:18.744211 [ 23606 ] {c5dd0795-8b48-42f6-9acb-7a5f687e69b0} executeQuery: Code: 36. DB::Exception: Parameter for function 'groupArray' expected to have constant value. Actual throwIf(1). In scope SELECT groupArray(throwIf(1))(number) FROM numbers(10). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44612) (comment: 01934_constexpr_aggregate_function_parameters.sql) (in query: SELECT groupArray(throwIf(1))(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000002951b6a3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a9058 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:18.744489 [ 23606 ] {c5dd0795-8b48-42f6-9acb-7a5f687e69b0} TCPHandler: Code: 36. DB::Exception: Parameter for function 'groupArray' expected to have constant value. Actual throwIf(1). In scope SELECT groupArray(throwIf(1))(number) FROM numbers(10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000002951b6a3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a9058 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:18.746639 [ 23606 ] {0b564eb3-9fe0-405b-8702-d4cbaefd9f08} executeQuery: Code: 36. DB::Exception: Parameter for function 'groupArray' expected to have constant value. Actual number. In scope SELECT groupArray(number)(number) FROM numbers(10). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44612) (comment: 01934_constexpr_aggregate_function_parameters.sql) (in query: -- Not the best error message, can be improved. SELECT groupArray(number)(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000002951b6a3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a9058 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:18.746747 [ 23606 ] {0b564eb3-9fe0-405b-8702-d4cbaefd9f08} TCPHandler: Code: 36. DB::Exception: Parameter for function 'groupArray' expected to have constant value. Actual number. In scope SELECT groupArray(number)(number) FROM numbers(10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000002951b6a3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a9058 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:18.957745 [ 48601 ] {1e2ef214-b2aa-46e9-a02e-7a5d3e088a5c} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 07-08-2019: Cannot parse Date from String: In scope SELECT toDate('07-08-2019'). (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:41232) (comment: 01933_invalid_date.sql) (in query: SELECT toDate('07-08-2019');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x0000000018653ffb 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018643e8d 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:13:18.957963 [ 48601 ] {1e2ef214-b2aa-46e9-a02e-7a5d3e088a5c} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 07-08-2019: Cannot parse Date from String: In scope SELECT toDate('07-08-2019'). (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x0000000018653ffb 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018643e8d 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:13:18.986533 [ 48601 ] {a12d5acc-0938-4c54-899a-1db8e3494a0e} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: In scope SELECT toDate('2019-0708'). (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:41232) (comment: 01933_invalid_date.sql) (in query: SELECT toDate('2019-0708');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/ReadHelpers.cpp:1142: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x000000002471fb27 5. ./build_docker/./src/IO/ReadHelpers.cpp:1200: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&) @ 0x000000002471f891 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x0000000018653ffb 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018643e8d 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:13:18.986811 [ 48601 ] {a12d5acc-0938-4c54-899a-1db8e3494a0e} TCPHandler: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: In scope SELECT toDate('2019-0708'). (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/ReadHelpers.cpp:1142: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x000000002471fb27 5. ./build_docker/./src/IO/ReadHelpers.cpp:1200: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&) @ 0x000000002471f891 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x0000000018653ffb 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018643e8d 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:13:18.988834 [ 48601 ] {112d800e-1052-4a35-b3bd-ec1aa81f9fe9} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: In scope SELECT toDate('201907-08'). (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:41232) (comment: 01933_invalid_date.sql) (in query: SELECT toDate('201907-08');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/ReadHelpers.cpp:1142: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x000000002471fb27 5. ./build_docker/./src/IO/ReadHelpers.cpp:1200: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&) @ 0x000000002471f891 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x0000000018653ffb 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018643e8d 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:13:18.988951 [ 48601 ] {112d800e-1052-4a35-b3bd-ec1aa81f9fe9} TCPHandler: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: In scope SELECT toDate('201907-08'). (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/ReadHelpers.cpp:1142: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x000000002471fb27 5. ./build_docker/./src/IO/ReadHelpers.cpp:1200: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&) @ 0x000000002471f891 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x0000000018653ffb 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018643e8d 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:13:19.039445 [ 48601 ] {efe5c5b7-0389-4da6-8b80-39f6bcdc3bd5} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 07-08-2019: while converting '07-08-2019' to Date. (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:41232) (comment: 01933_invalid_date.sql) (in query: SELECT * FROM test WHERE d >= '07-08-2019';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5ca3dc 7. ./build_docker/./src/DataTypes/Serializations/SerializationDate.cpp:21: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5ca1a4 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031699857 9. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 10. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c290c8a 11. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c271325 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 20. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 21. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 22. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 23. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:13:19.039708 [ 48601 ] {efe5c5b7-0389-4da6-8b80-39f6bcdc3bd5} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 07-08-2019: while converting '07-08-2019' to Date. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&)::'lambda'()::operator()() const @ 0x00000000187be399 5. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&) @ 0x00000000187be091 6. ./src/Common/LocalDate.h:116: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5ca3dc 7. ./build_docker/./src/DataTypes/Serializations/SerializationDate.cpp:21: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5ca1a4 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031699857 9. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 10. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c290c8a 11. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c271325 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 20. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 21. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 22. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 23. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:13:19.288756 [ 22859 ] {c1acab8f-d198-4175-8e14-b0434b11e368} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), '^data$') does not support column __table1._table in PREWHERE. In query SELECT 1 FROM merge(currentDatabase(), '^data$') PREWHERE _table IN (NULL). (ILLEGAL_PREWHERE) (version 24.3.12.76.altinitystable) (from [::1]:41430) (comment: 01931_storage_merge_no_columns.sql) (in query: select 1 from merge(currentDatabase(), '^data$') prewhere _table in (NULL);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000310389cf 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000310343c1 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008f36 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:19.288893 [ 22859 ] {c1acab8f-d198-4175-8e14-b0434b11e368} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), '^data$') does not support column __table1._table in PREWHERE. In query SELECT 1 FROM merge(currentDatabase(), '^data$') PREWHERE _table IN (NULL). (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000310389cf 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:91: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031037d7a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000310343c1 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008f36 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:19.645897 [ 22866 ] {a4ba375b-7d79-4358-bbe3-565af9d3a000} executeQuery: Code: 248. DB::Exception: Invalid partition format: 20210325_0_13241_6_12747. (INVALID_PARTITION_VALUE) (version 24.3.12.76.altinitystable) (from [::1]:41560) (comment: 01925_broken_partition_id_zookeeper.sql) (in query: ALTER TABLE broken_partition DROP PARTITION ID '20210325_0_13241_6_12747';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:50: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x0000000032d7ec2f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000032b46fcc 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4890: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000032b7866d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307958ad 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:19.646141 [ 22866 ] {a4ba375b-7d79-4358-bbe3-565af9d3a000} TCPHandler: Code: 248. DB::Exception: Invalid partition format: 20210325_0_13241_6_12747. (INVALID_PARTITION_VALUE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:50: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x0000000032d7ec2f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000032b46fcc 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4890: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000032b7866d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307958ad 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:19.649624 [ 22866 ] {ff668994-857a-4369-83e1-05e209f90dd3} executeQuery: Code: 248. DB::Exception: Invalid partition format: 20210325_0_13241_6_12747. (INVALID_PARTITION_VALUE) (version 24.3.12.76.altinitystable) (from [::1]:41560) (comment: 01925_broken_partition_id_zookeeper.sql) (in query: ALTER TABLE broken_partition DROP PARTITION ID '20210325_0_13241_6_12747';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:50: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x0000000032d7ec2f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000032b46fcc 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4890: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000032b7866d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307958ad 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:19.649732 [ 22866 ] {ff668994-857a-4369-83e1-05e209f90dd3} TCPHandler: Code: 248. DB::Exception: Invalid partition format: 20210325_0_13241_6_12747. (INVALID_PARTITION_VALUE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:50: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x0000000032d7ec2f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000032b46fcc 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4890: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000032b7866d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307958ad 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:19.698252 [ 22866 ] {85e2854e-5503-405a-898b-4c1359ed8a3f} executeQuery: Code: 248. DB::Exception: Invalid partition format: 20210325_0_13241_6_12747. Partition should consist of 6 digits: YYYYMM. (INVALID_PARTITION_VALUE) (version 24.3.12.76.altinitystable) (from [::1]:41560) (comment: 01925_broken_partition_id_zookeeper.sql) (in query: ALTER TABLE old_partition_key DROP PARTITION ID '20210325_0_13241_6_12747';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:42: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x0000000032d7ecbd 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000032b46fcc 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4890: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000032b7866d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307958ad 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:19.698516 [ 22866 ] {85e2854e-5503-405a-898b-4c1359ed8a3f} TCPHandler: Code: 248. DB::Exception: Invalid partition format: 20210325_0_13241_6_12747. Partition should consist of 6 digits: YYYYMM. (INVALID_PARTITION_VALUE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:42: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x0000000032d7ecbd 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000032b46fcc 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4890: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000032b7866d 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307958ad 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:20.381863 [ 22866 ] {22e5fb36-5fd3-4fda-979d-3bfa8c85a5d7} executeQuery: Code: 403. DB::Exception: JOIN test_7t22fjr3.t1 AS __table1 ALL INNER JOIN test_7t22fjr3.t2 AS __table2 ON __table1.time = __table1.time cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:41702) (comment: 01925_join_materialized_columns.sql) (in query: SELECT time as talias FROM t1 JOIN t2 ON t1.time = talias;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:20.382004 [ 22866 ] {22e5fb36-5fd3-4fda-979d-3bfa8c85a5d7} TCPHandler: Code: 403. DB::Exception: JOIN test_7t22fjr3.t1 AS __table1 ALL INNER JOIN test_7t22fjr3.t2 AS __table2 ON __table1.time = __table1.time cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:20.407175 [ 22866 ] {21233ac2-c428-4b6a-be61-cadd306e5c39} executeQuery: Code: 352. DB::Exception: Column 'time' is ambiguous: While processing (time AS talias) = t2.time. (AMBIGUOUS_COLUMN_NAME) (version 24.3.12.76.altinitystable) (from [::1]:41702) (comment: 01925_join_materialized_columns.sql) (in query: SELECT time as talias FROM t1 JOIN t2 ON talias = t2.time settings allow_experimental_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:256: DB::CollectJoinOnKeysMatcher::getTableForIdentifiers(std::shared_ptr const&, bool, DB::CollectJoinOnKeysMatcher::Data const&) @ 0x0000000031650f95 5. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:0: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000316517f5 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000315d60cd 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::(anonymous namespace)::collectJoinedColumns(DB::TableJoin&, DB::ASTTableJoin&, std::vector> const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr) @ 0x00000000315c2d68 8. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x00000000315bd821 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f5eb42 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:20.408571 [ 22866 ] {21233ac2-c428-4b6a-be61-cadd306e5c39} TCPHandler: Code: 352. DB::Exception: Column 'time' is ambiguous: While processing (time AS talias) = t2.time. (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:256: DB::CollectJoinOnKeysMatcher::getTableForIdentifiers(std::shared_ptr const&, bool, DB::CollectJoinOnKeysMatcher::Data const&) @ 0x0000000031650f95 5. ./build_docker/./src/Interpreters/CollectJoinOnKeysVisitor.cpp:0: DB::CollectJoinOnKeysMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::CollectJoinOnKeysMatcher::Data&) @ 0x00000000316517f5 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x00000000315d60cd 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::(anonymous namespace)::collectJoinedColumns(DB::TableJoin&, DB::ASTTableJoin&, std::vector> const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr) @ 0x00000000315c2d68 8. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x00000000315bd821 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f5eb42 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:23.085750 [ 48614 ] {b0765e76-fe15-44fe-8696-a4ce67f9fea2} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 128.03 MiB (attempt to allocate chunk of 134251936 bytes), maximum: 95.37 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:42956) (comment: 01910_memory_tracking_topk.sql) (in query: SELECT length(topK(5592405)(tuple(number))) FROM numbers(10) GROUP BY number;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./src/Common/AllocatorWithMemoryTracking.h:0: AllocatorWithMemoryTracking::Counter, std::default_delete::Counter>>>::allocate(unsigned long) @ 0x000000002858af23 8. ./contrib/llvm-project/libcxx/include/__split_buffer:0: std::vector::Counter, std::default_delete::Counter>>, AllocatorWithMemoryTracking::Counter, std::default_delete::Counter>>>>::reserve(unsigned long) @ 0x000000002858ac73 9. ./src/Common/SpaceSaving.h:84: DB::SpaceSaving::resize(unsigned long) @ 0x000000002858a719 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionTopK.cpp:0: DB::(anonymous namespace)::AggregateFunctionTopKGeneric::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x00000000284aca25 11. ./src/AggregateFunctions/IAggregateFunction.h:0: DB::IAggregateFunctionHelper>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000284ae7cd 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1380: DB::Aggregator::addBatch(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char**, DB::Arena*) @ 0x000000002fe5ead4 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x000000002fe5df78 14. ./build_docker/./src/Interpreters/Aggregator.cpp:1228: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003005dd5f 15. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003005b7c6 16. ./build_docker/./src/Interpreters/Aggregator.cpp:984: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002fef56b4 17. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002fe5af49 18. ./build_docker/./src/Interpreters/Aggregator.cpp:1626: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe6411b 19. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 20. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:23.086252 [ 48614 ] {b0765e76-fe15-44fe-8696-a4ce67f9fea2} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 128.03 MiB (attempt to allocate chunk of 134251936 bytes), maximum: 95.37 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./src/Common/AllocatorWithMemoryTracking.h:0: AllocatorWithMemoryTracking::Counter, std::default_delete::Counter>>>::allocate(unsigned long) @ 0x000000002858af23 8. ./contrib/llvm-project/libcxx/include/__split_buffer:0: std::vector::Counter, std::default_delete::Counter>>, AllocatorWithMemoryTracking::Counter, std::default_delete::Counter>>>>::reserve(unsigned long) @ 0x000000002858ac73 9. ./src/Common/SpaceSaving.h:84: DB::SpaceSaving::resize(unsigned long) @ 0x000000002858a719 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionTopK.cpp:0: DB::(anonymous namespace)::AggregateFunctionTopKGeneric::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x00000000284aca25 11. ./src/AggregateFunctions/IAggregateFunction.h:0: DB::IAggregateFunctionHelper>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000284ae7cd 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1380: DB::Aggregator::addBatch(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char**, DB::Arena*) @ 0x000000002fe5ead4 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x000000002fe5df78 14. ./build_docker/./src/Interpreters/Aggregator.cpp:1228: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003005dd5f 15. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003005b7c6 16. ./build_docker/./src/Interpreters/Aggregator.cpp:984: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002fef56b4 17. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002fe5af49 18. ./build_docker/./src/Interpreters/Aggregator.cpp:1626: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe6411b 19. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 20. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:25.321511 [ 23620 ] {26583295-9a1e-43fd-beba-fdf28797a771} executeQuery: Code: 174. DB::Exception: Self referencing of `x` to `x`. Cyclic alias: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 24.3.12.76.altinitystable) (from [::1]:44002) (comment: 01902_self_aliases_in_columns.sql) (in query: CREATE TABLE a (`number` UInt64, `x` MATERIALIZED x) ENGINE = MergeTree ORDER BY number SETTINGS index_granularity = 33335, min_bytes_for_wide_part = 922916407, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 49164005, compact_parts_max_granules_to_buffer = 94, compact_parts_merge_max_bytes_to_prefetch_part = 9208868, merge_max_block_size = 17449, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 883363, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 3459259, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 89509, primary_key_compress_block_size = 45202), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003164ae67 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003164c416 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:256: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003164ddc4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003164c74d 8. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x00000000315c1811 9. ./contrib/llvm-project/libcxx/include/__tree:1097: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000315c6c1c 10. ./build_docker/./src/Storages/ColumnsDescription.cpp:0: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000320a6109 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b25b1 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:25.321718 [ 23620 ] {26583295-9a1e-43fd-beba-fdf28797a771} TCPHandler: Code: 174. DB::Exception: Self referencing of `x` to `x`. Cyclic alias: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003164ae67 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003164c416 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:256: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003164ddc4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003164c74d 8. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x00000000315c1811 9. ./contrib/llvm-project/libcxx/include/__tree:1097: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000315c6c1c 10. ./build_docker/./src/Storages/ColumnsDescription.cpp:0: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000320a6109 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b25b1 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:25.345749 [ 23620 ] {1b2d201b-c7f4-4415-850d-57319d394fcf} executeQuery: Code: 174. DB::Exception: Self referencing of `j` to `j`. Cyclic alias: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 24.3.12.76.altinitystable) (from [::1]:44002) (comment: 01902_self_aliases_in_columns.sql) (in query: CREATE TABLE foo (`i` Int32, `j` ALIAS j + 1) ENGINE = MergeTree ORDER BY i SETTINGS index_granularity = 33335, min_bytes_for_wide_part = 922916407, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 49164005, compact_parts_max_granules_to_buffer = 94, compact_parts_merge_max_bytes_to_prefetch_part = 9208868, merge_max_block_size = 17449, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 883363, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 3459259, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 89509, primary_key_compress_block_size = 45202), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003164ae67 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003164c416 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003164e3b0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003164c74d 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:256: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003164ddc4 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003164c74d 10. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x00000000315c1811 11. ./contrib/llvm-project/libcxx/include/__tree:1097: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000315c6c1c 12. ./build_docker/./src/Storages/ColumnsDescription.cpp:0: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000320a6109 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b25b1 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:25.345968 [ 23620 ] {1b2d201b-c7f4-4415-850d-57319d394fcf} TCPHandler: Code: 174. DB::Exception: Self referencing of `j` to `j`. Cyclic alias: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003164ae67 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003164c416 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003164e3b0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003164c74d 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:256: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003164ddc4 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003164c74d 10. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x00000000315c1811 11. ./contrib/llvm-project/libcxx/include/__tree:1097: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000315c6c1c 12. ./build_docker/./src/Storages/ColumnsDescription.cpp:0: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000320a6109 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b25b1 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:31.410509 [ 48631 ] {074f5aed-ec7d-4a0d-afba-e0c3a4950e3f} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_VALUE('{"1key":1}', '$..1key'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:43318) (comment: 01889_sql_json_functions.sql) (in query: SELECT JSON_VALUE('{"1key":1}', '$..1key');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180b4365 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b332d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:13:31.410728 [ 48631 ] {074f5aed-ec7d-4a0d-afba-e0c3a4950e3f} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_VALUE('{"1key":1}', '$..1key'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180b4365 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b332d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:13:31.412960 [ 48631 ] {ac202a53-9cad-466b-acce-e12f89d76d7d} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_VALUE('{"1key":1}', '$1key'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:43318) (comment: 01889_sql_json_functions.sql) (in query: SELECT JSON_VALUE('{"1key":1}', '$1key');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180b4365 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b332d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:13:31.413066 [ 48631 ] {ac202a53-9cad-466b-acce-e12f89d76d7d} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_VALUE('{"1key":1}', '$1key'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180b4365 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b332d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:13:31.414367 [ 48631 ] {62f560ed-8044-4df2-bd7c-9445cee71f8a} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_VALUE('{"1key":1}', '$key'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:43318) (comment: 01889_sql_json_functions.sql) (in query: SELECT JSON_VALUE('{"1key":1}', '$key');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180b4365 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b332d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:13:31.414471 [ 48631 ] {62f560ed-8044-4df2-bd7c-9445cee71f8a} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_VALUE('{"1key":1}', '$key'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180b4365 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b332d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:13:31.415725 [ 48631 ] {00fb5f0b-44a1-440b-8b9b-dcc11b4f9ef7} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_VALUE('{"1key":1}', '$.[key]'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:43318) (comment: 01889_sql_json_functions.sql) (in query: SELECT JSON_VALUE('{"1key":1}', '$.[key]');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180b4365 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b332d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:13:31.415885 [ 48631 ] {00fb5f0b-44a1-440b-8b9b-dcc11b4f9ef7} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_VALUE('{"1key":1}', '$.[key]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180b4365 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180b332d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:13:31.496637 [ 48631 ] {256e51f2-b349-4e4d-b3d3-37bbab5dee80} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_QUERY('{"1key":1}', '$..1key'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:43318) (comment: 01889_sql_json_functions.sql) (in query: SELECT JSON_QUERY('{"1key":1}', '$..1key');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180adae5 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180acaad 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:13:31.496902 [ 48631 ] {256e51f2-b349-4e4d-b3d3-37bbab5dee80} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_QUERY('{"1key":1}', '$..1key'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180adae5 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180acaad 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:13:31.499772 [ 48631 ] {92becc61-a7df-47d2-80a7-9c7098d3f80a} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_QUERY('{"1key":1}', '$1key'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:43318) (comment: 01889_sql_json_functions.sql) (in query: SELECT JSON_QUERY('{"1key":1}', '$1key');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180adae5 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180acaad 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:13:31.499887 [ 48631 ] {92becc61-a7df-47d2-80a7-9c7098d3f80a} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_QUERY('{"1key":1}', '$1key'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180adae5 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180acaad 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:13:31.501151 [ 48631 ] {3a2ffc13-0a85-47a4-b507-bbbe047ab66c} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_QUERY('{"1key":1}', '$key'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:43318) (comment: 01889_sql_json_functions.sql) (in query: SELECT JSON_QUERY('{"1key":1}', '$key');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180adae5 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180acaad 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:13:31.501254 [ 48631 ] {3a2ffc13-0a85-47a4-b507-bbbe047ab66c} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_QUERY('{"1key":1}', '$key'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180adae5 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180acaad 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:13:31.502439 [ 48631 ] {9c90d8ba-b2de-4a16-b627-b7401db83138} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_QUERY('{"1key":1}', '$.[key]'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:43318) (comment: 01889_sql_json_functions.sql) (in query: SELECT JSON_QUERY('{"1key":1}', '$.[key]');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180adae5 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180acaad 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:13:31.502536 [ 48631 ] {9c90d8ba-b2de-4a16-b627-b7401db83138} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_QUERY('{"1key":1}', '$.[key]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, std::shared_ptr const&) @ 0x00000000180adae5 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180acaad 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:13:31.691796 [ 48631 ] {058b34b1-ca0a-4ec7-a5d0-3dd506c6cc51} executeQuery: Code: 72. DB::Exception: Cannot parse number with multiple sign (+/-) characters: Cannot parse Int64 from String: In scope SELECT toInt64('--1'). (CANNOT_PARSE_NUMBER) (version 24.3.12.76.altinitystable) (from [::1]:43466) (comment: 01888_read_int_safe.sql) (in query: select toInt64('--1');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::readIntTextImpl(long&, DB::ReadBuffer&) @ 0x00000000187a5b80 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000183790d8 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:13:31.692064 [ 48631 ] {058b34b1-ca0a-4ec7-a5d0-3dd506c6cc51} TCPHandler: Code: 72. DB::Exception: Cannot parse number with multiple sign (+/-) characters: Cannot parse Int64 from String: In scope SELECT toInt64('--1'). (CANNOT_PARSE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::readIntTextImpl(long&, DB::ReadBuffer&) @ 0x00000000187a5b80 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000183790d8 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:13:31.694490 [ 48631 ] {ba65e6af-2d4e-494e-878c-656fd1ebdf4e} executeQuery: Code: 72. DB::Exception: Cannot parse number with multiple sign (+/-) characters: Cannot parse Int64 from String: In scope SELECT toInt64('+-1'). (CANNOT_PARSE_NUMBER) (version 24.3.12.76.altinitystable) (from [::1]:43466) (comment: 01888_read_int_safe.sql) (in query: select toInt64('+-1');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::readIntTextImpl(long&, DB::ReadBuffer&) @ 0x00000000187a5b80 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000183790d8 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:13:31.694606 [ 48631 ] {ba65e6af-2d4e-494e-878c-656fd1ebdf4e} TCPHandler: Code: 72. DB::Exception: Cannot parse number with multiple sign (+/-) characters: Cannot parse Int64 from String: In scope SELECT toInt64('+-1'). (CANNOT_PARSE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::readIntTextImpl(long&, DB::ReadBuffer&) @ 0x00000000187a5b80 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000183790d8 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:13:31.725802 [ 48631 ] {04b44346-b553-4d3b-9c32-79c8bd042a5d} executeQuery: Code: 72. DB::Exception: Cannot parse number with multiple sign (+/-) characters: Cannot parse Int64 from String: In scope SELECT toInt64('++1'). (CANNOT_PARSE_NUMBER) (version 24.3.12.76.altinitystable) (from [::1]:43466) (comment: 01888_read_int_safe.sql) (in query: select toInt64('++1');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::readIntTextImpl(long&, DB::ReadBuffer&) @ 0x00000000187a5b1c 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000183790d8 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:13:31.726116 [ 48631 ] {04b44346-b553-4d3b-9c32-79c8bd042a5d} TCPHandler: Code: 72. DB::Exception: Cannot parse number with multiple sign (+/-) characters: Cannot parse Int64 from String: In scope SELECT toInt64('++1'). (CANNOT_PARSE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::readIntTextImpl(long&, DB::ReadBuffer&) @ 0x00000000187a5b1c 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000183790d8 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:13:31.728267 [ 48631 ] {f4b39f3b-05f6-4df2-822f-b78cec7a6bb1} executeQuery: Code: 72. DB::Exception: Cannot parse number with multiple sign (+/-) characters: Cannot parse Int64 from String: In scope SELECT toInt64('++'). (CANNOT_PARSE_NUMBER) (version 24.3.12.76.altinitystable) (from [::1]:43466) (comment: 01888_read_int_safe.sql) (in query: select toInt64('++');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::readIntTextImpl(long&, DB::ReadBuffer&) @ 0x00000000187a5b1c 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000183790d8 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:13:31.728385 [ 48631 ] {f4b39f3b-05f6-4df2-822f-b78cec7a6bb1} TCPHandler: Code: 72. DB::Exception: Cannot parse number with multiple sign (+/-) characters: Cannot parse Int64 from String: In scope SELECT toInt64('++'). (CANNOT_PARSE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::readIntTextImpl(long&, DB::ReadBuffer&) @ 0x00000000187a5b1c 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000183790d8 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:13:31.760133 [ 48631 ] {5f9fedaa-7c08-4010-a719-41957d212c1d} executeQuery: Code: 72. DB::Exception: Cannot parse number with a sign character but without any numeric character: Cannot parse Int64 from String: In scope SELECT toInt64('+'). (CANNOT_PARSE_NUMBER) (version 24.3.12.76.altinitystable) (from [::1]:43466) (comment: 01888_read_int_safe.sql) (in query: select toInt64('+');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::readIntTextImpl(long&, DB::ReadBuffer&) @ 0x00000000187a5c2e 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000183790d8 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:13:31.760416 [ 48631 ] {5f9fedaa-7c08-4010-a719-41957d212c1d} TCPHandler: Code: 72. DB::Exception: Cannot parse number with a sign character but without any numeric character: Cannot parse Int64 from String: In scope SELECT toInt64('+'). (CANNOT_PARSE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::readIntTextImpl(long&, DB::ReadBuffer&) @ 0x00000000187a5c2e 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000183790d8 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:13:31.792881 [ 48631 ] {4ea485c8-7cc5-423a-a96b-eb3ac81bfe9a} executeQuery: Code: 6. DB::Exception: Cannot parse string '1+1' as Int64: syntax error at position 1 (parsed just '1'). Note: there are toInt64OrZero and toInt64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT toInt64('1+1'). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:43466) (comment: 01888_read_int_safe.sql) (in query: select toInt64('1+1');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001837a2a0 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:13:31.793148 [ 48631 ] {4ea485c8-7cc5-423a-a96b-eb3ac81bfe9a} TCPHandler: Code: 6. DB::Exception: Cannot parse string '1+1' as Int64: syntax error at position 1 (parsed just '1'). Note: there are toInt64OrZero and toInt64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT toInt64('1+1'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001837a2a0 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:13:31.795166 [ 48631 ] {0699fd9f-1318-439b-a853-d659f3d77af5} executeQuery: Code: 6. DB::Exception: Cannot parse string '1-1' as Int64: syntax error at position 1 (parsed just '1'). Note: there are toInt64OrZero and toInt64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT toInt64('1-1'). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:43466) (comment: 01888_read_int_safe.sql) (in query: select toInt64('1-1');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001837a2a0 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:13:31.795292 [ 48631 ] {0699fd9f-1318-439b-a853-d659f3d77af5} TCPHandler: Code: 6. DB::Exception: Cannot parse string '1-1' as Int64: syntax error at position 1 (parsed just '1'). Note: there are toInt64OrZero and toInt64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT toInt64('1-1'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001837a2a0 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:13:31.827307 [ 48631 ] {b2f3e2d9-6a95-45e4-87d8-6e8cfbbb11d4} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse Int64 from String, because value is too short: In scope SELECT toInt64(''). (ATTEMPT_TO_READ_AFTER_EOF) (version 24.3.12.76.altinitystable) (from [::1]:43466) (comment: 01888_read_int_safe.sql) (in query: select toInt64('');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x00000000247381ce 5. void DB::readIntTextImpl(long&, DB::ReadBuffer&) @ 0x00000000187a5a81 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000183790d8 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:13:31.827518 [ 48631 ] {b2f3e2d9-6a95-45e4-87d8-6e8cfbbb11d4} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse Int64 from String, because value is too short: In scope SELECT toInt64(''). (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x00000000247381ce 5. void DB::readIntTextImpl(long&, DB::ReadBuffer&) @ 0x00000000187a5a81 6. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000183790d8 7. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:13:31.974644 [ 23590 ] {e20c8713-0f05-4538-a0cd-979c914d87a0} executeQuery: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), Int8 because some of them are Array and some of them are not. (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:43544) (comment: 01888_bloom_filter_hasAny.sql) (in query: SELECT count() FROM bftest WHERE hasAny(y, [[123], -42]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:88: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ee80 6. ./build_docker/./src/DataTypes/FieldToDataType.cpp:143: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x000000002f543d56 7. ./build_docker/./src/Analyzer/ConstantNode.cpp:41: DB::ConstantNode::ConstantNode(DB::Field) @ 0x000000002fadc4de 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, DB::Field const&) @ 0x000000003083c5f1 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::Field const&, void>(std::allocator const&, DB::Field const&) @ 0x000000003083c37e 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:557: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003081441c 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:621: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030815587 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819f6e 13. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:31.974897 [ 23590 ] {e20c8713-0f05-4538-a0cd-979c914d87a0} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), Int8 because some of them are Array and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:88: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ee80 6. ./build_docker/./src/DataTypes/FieldToDataType.cpp:143: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x000000002f543d56 7. ./build_docker/./src/Analyzer/ConstantNode.cpp:41: DB::ConstantNode::ConstantNode(DB::Field) @ 0x000000002fadc4de 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, DB::Field const&) @ 0x000000003083c5f1 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::Field const&, void>(std::allocator const&, DB::Field const&) @ 0x000000003083c37e 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:557: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003081441c 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:621: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030815587 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819f6e 13. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:32.087040 [ 23590 ] {dd596405-32fe-4069-804c-c472799083f9} executeQuery: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:43544) (comment: 01888_bloom_filter_hasAny.sql) (in query: -- can't use bloom_filter with `hasAny` on non-constant arguments (just like `has`) SELECT count() FROM bftest WHERE hasAny(x, materialize([1,2,3])) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:32.087279 [ 23590 ] {dd596405-32fe-4069-804c-c472799083f9} TCPHandler: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:32.092376 [ 23590 ] {d454313b-8095-4e6a-83b8-abf92b4bfb4f} executeQuery: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:43544) (comment: 01888_bloom_filter_hasAny.sql) (in query: -- NULLs are not Ok SELECT count() FROM bftest WHERE hasAny(x, [NULL,-42]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:32.092511 [ 23590 ] {d454313b-8095-4e6a-83b8-abf92b4bfb4f} TCPHandler: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:32.095504 [ 23590 ] {88c5b6d9-544a-45e8-9a8a-360fb936aac2} executeQuery: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:43544) (comment: 01888_bloom_filter_hasAny.sql) (in query: SELECT count() FROM bftest WHERE hasAny(x, [0,NULL]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:32.095627 [ 23590 ] {88c5b6d9-544a-45e8-9a8a-360fb936aac2} TCPHandler: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:32.097158 [ 23590 ] {610d6725-6452-4b5f-9ae2-a31f6822fd04} executeQuery: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), Int8 because some of them are Array and some of them are not. (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:43544) (comment: 01888_bloom_filter_hasAny.sql) (in query: -- non-compatible types SELECT count() FROM bftest WHERE hasAny(x, [[123], -42]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:88: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ee80 6. ./build_docker/./src/DataTypes/FieldToDataType.cpp:143: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x000000002f543d56 7. ./build_docker/./src/Analyzer/ConstantNode.cpp:41: DB::ConstantNode::ConstantNode(DB::Field) @ 0x000000002fadc4de 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, DB::Field const&) @ 0x000000003083c5f1 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::Field const&, void>(std::allocator const&, DB::Field const&) @ 0x000000003083c37e 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:557: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003081441c 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:621: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030815587 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819f6e 13. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:32.097281 [ 23590 ] {610d6725-6452-4b5f-9ae2-a31f6822fd04} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), Int8 because some of them are Array and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:88: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ee80 6. ./build_docker/./src/DataTypes/FieldToDataType.cpp:143: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x000000002f543d56 7. ./build_docker/./src/Analyzer/ConstantNode.cpp:41: DB::ConstantNode::ConstantNode(DB::Field) @ 0x000000002fadc4de 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, DB::Field const&) @ 0x000000003083c5f1 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::Field const&, void>(std::allocator const&, DB::Field const&) @ 0x000000003083c37e 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:557: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003081441c 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:621: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030815587 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819f6e 13. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:32.100049 [ 23590 ] {75a9342d-277b-4a5b-a883-275b4bbc320c} executeQuery: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:43544) (comment: 01888_bloom_filter_hasAny.sql) (in query: SELECT count() FROM bftest WHERE hasAny(x, [toDecimal32(123, 3), 2]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:32.100250 [ 23590 ] {75a9342d-277b-4a5b-a883-275b4bbc320c} TCPHandler: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:32.262847 [ 10241 ] {430e76a0-5ca0-493a-ac2d-6dcd86615900} executeQuery: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:43604) (comment: 01883_with_grouping_sets.sql) (in query: SELECT fact_1_id, fact_3_id, SUM(sales_value) AS sales_value FROM grouping_sets GROUP BY grouping sets ((fact_1_id), (fact_1_id, fact_3_id)) WITH TOTALS ORDER BY fact_1_id, fact_3_id;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308796fd 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:32.263162 [ 10241 ] {430e76a0-5ca0-493a-ac2d-6dcd86615900} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308796fd 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:32.267990 [ 10241 ] {1b091894-f4bb-444d-b395-789ccda74773} executeQuery: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:43604) (comment: 01883_with_grouping_sets.sql) (in query: SELECT fact_1_id, fact_3_id, SUM(sales_value) AS sales_value FROM grouping_sets GROUP BY grouping sets (fact_1_id, (fact_1_id, fact_3_id)) WITH TOTALS ORDER BY fact_1_id, fact_3_id;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308796fd 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:32.268123 [ 10241 ] {1b091894-f4bb-444d-b395-789ccda74773} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308796fd 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:32.461548 [ 23620 ] {3d747f2e-939c-462f-bb6d-1d78c840e08d} executeQuery: Code: 47. DB::Exception: Identifier '__table1.arr.size0' cannot be resolved from table with name __table1. In scope SELECT __table1.`arr.size0` AS `arr.size0`, __table1.`n.null` AS `n.null`, __table1.`t.s1` AS `t.s1`, __table1.`t.s2` AS `t.s2` FROM test_4v3kjxpq.t_subcolumns_local AS __table1. Maybe you meant: ['__table1.arr']. (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:43696) (comment: 01883_subcolumns_distributed.sql) (in query: SELECT arr.size0, n.null, t.s1, t.s2 FROM t_subcolumns_dist;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000003091f2a1 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::(anonymous namespace)::TableExpressionData const&, DB::(anonymous namespace)::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000308d6d5b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7872 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./contrib/llvm-project/libcxx/include/vector:1457: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x0000000030866007 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000030865d25 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe6e4 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:0: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb47f4 18. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 19. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 23. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 24. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 25. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:13:32.461770 [ 23620 ] {3d747f2e-939c-462f-bb6d-1d78c840e08d} TCPHandler: Code: 47. DB::Exception: Identifier '__table1.arr.size0' cannot be resolved from table with name __table1. In scope SELECT __table1.`arr.size0` AS `arr.size0`, __table1.`n.null` AS `n.null`, __table1.`t.s1` AS `t.s1`, __table1.`t.s2` AS `t.s2` FROM test_4v3kjxpq.t_subcolumns_local AS __table1. Maybe you meant: ['__table1.arr']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000003091f2a1 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::(anonymous namespace)::TableExpressionData const&, DB::(anonymous namespace)::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000308d6d5b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7872 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./contrib/llvm-project/libcxx/include/vector:1457: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x0000000030866007 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000030865d25 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe6e4 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:0: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb47f4 18. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 19. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 23. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 24. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 25. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:13:32.796873 [ 23635 ] {c24b6739-0c0e-4d3d-a45a-0477defbc846} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.3.12.76.altinitystable) (from [::1]:43946) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:32.797020 [ 23635 ] {c24b6739-0c0e-4d3d-a45a-0477defbc846} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:34.935253 [ 5753 ] {6d51aae6-3855-456b-bac8-d5fb93e8e6c8} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2CapUnion. Must be UInt64: In scope SELECT s2CapUnion(nan, 3.14, 1157339245694594829, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:44802) (comment: 01854_s2_cap_union.sql) (in query: select s2CapUnion(nan, 3.14, 1157339245694594829, 3.14);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000018082175 4. DB::(anonymous namespace)::FunctionS2CapUnion::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002154b6af 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:34.959178 [ 5753 ] {6d51aae6-3855-456b-bac8-d5fb93e8e6c8} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2CapUnion. Must be UInt64: In scope SELECT s2CapUnion(nan, 3.14, 1157339245694594829, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000018082175 4. DB::(anonymous namespace)::FunctionS2CapUnion::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002154b6af 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:34.959421 [ 14920 ] {ec4aee89-3b1d-45c4-aa47-abae1ab038c1} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2CapContains. Must be UInt64: In scope SELECT s2CapContains(nan, 3.14, 1157339245694594829). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:44810) (comment: 01854_s2_cap_contains.sql) (in query: select s2CapContains(nan, 3.14, 1157339245694594829);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000018082175 4. DB::(anonymous namespace)::FunctionS2CapContains::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000021547d3d 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:34.959712 [ 14920 ] {ec4aee89-3b1d-45c4-aa47-abae1ab038c1} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2CapContains. Must be UInt64: In scope SELECT s2CapContains(nan, 3.14, 1157339245694594829). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000018082175 4. DB::(anonymous namespace)::FunctionS2CapContains::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000021547d3d 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:34.987807 [ 5753 ] {73e6506c-e120-4521-b806-3ca87d1f6821} executeQuery: Code: 43. DB::Exception: Radius of the cap must not be nan: In scope SELECT s2CapUnion(1157339245694594829, nan, 1157339245694594829, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:44802) (comment: 01854_s2_cap_union.sql) (in query: select s2CapUnion(1157339245694594829, nan, 1157339245694594829, 3.14);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::FunctionS2CapUnion::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002154a53f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:13:35.014615 [ 14920 ] {0c3ed026-4d1c-444a-b992-ddf0cb47fdaf} executeQuery: Code: 43. DB::Exception: Radius of the cap must not be nan in function s2CapContains: In scope SELECT s2CapContains(1157339245694594829, nan, 1157339245694594829). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:44810) (comment: 01854_s2_cap_contains.sql) (in query: select s2CapContains(1157339245694594829, nan, 1157339245694594829);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionS2CapContains::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021546c08 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:13:35.014759 [ 5753 ] {73e6506c-e120-4521-b806-3ca87d1f6821} TCPHandler: Code: 43. DB::Exception: Radius of the cap must not be nan: In scope SELECT s2CapUnion(1157339245694594829, nan, 1157339245694594829, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::FunctionS2CapUnion::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002154a53f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:13:35.014852 [ 14920 ] {0c3ed026-4d1c-444a-b992-ddf0cb47fdaf} TCPHandler: Code: 43. DB::Exception: Radius of the cap must not be nan in function s2CapContains: In scope SELECT s2CapContains(1157339245694594829, nan, 1157339245694594829). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionS2CapContains::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021546c08 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:13:35.017464 [ 5753 ] {0c19ace9-82f7-4889-85db-e01fe054bd62} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of argument 3 of function s2CapUnion. Must be UInt64: In scope SELECT s2CapUnion(1157339245694594829, 3.14, nan, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:44802) (comment: 01854_s2_cap_union.sql) (in query: select s2CapUnion(1157339245694594829, 3.14, nan, 3.14);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000018082175 4. DB::(anonymous namespace)::FunctionS2CapUnion::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002154b6af 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:35.017606 [ 5753 ] {0c19ace9-82f7-4889-85db-e01fe054bd62} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of argument 3 of function s2CapUnion. Must be UInt64: In scope SELECT s2CapUnion(1157339245694594829, 3.14, nan, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000018082175 4. DB::(anonymous namespace)::FunctionS2CapUnion::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002154b6af 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:35.018743 [ 14920 ] {a796872e-5469-48d6-9dd5-f75864f90872} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of argument 3 of function s2CapContains. Must be UInt64: In scope SELECT s2CapContains(1157339245694594829, 3.14, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:44810) (comment: 01854_s2_cap_contains.sql) (in query: select s2CapContains(1157339245694594829, 3.14, nan);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000018082175 4. DB::(anonymous namespace)::FunctionS2CapContains::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000021547d3d 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:35.018954 [ 14920 ] {a796872e-5469-48d6-9dd5-f75864f90872} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of argument 3 of function s2CapContains. Must be UInt64: In scope SELECT s2CapContains(1157339245694594829, 3.14, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000018082175 4. DB::(anonymous namespace)::FunctionS2CapContains::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000021547d3d 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:35.049216 [ 5753 ] {dd8d2d6b-1281-485e-bd9b-f7d1f2369d3d} executeQuery: Code: 43. DB::Exception: Radius of the cap must not be nan: In scope SELECT s2CapUnion(1157339245694594829, 3.14, 1157339245694594829, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:44802) (comment: 01854_s2_cap_union.sql) (in query: select s2CapUnion(1157339245694594829, 3.14, 1157339245694594829, nan);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::FunctionS2CapUnion::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002154a53f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:13:35.049437 [ 5753 ] {dd8d2d6b-1281-485e-bd9b-f7d1f2369d3d} TCPHandler: Code: 43. DB::Exception: Radius of the cap must not be nan: In scope SELECT s2CapUnion(1157339245694594829, 3.14, 1157339245694594829, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::FunctionS2CapUnion::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002154a53f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:13:35.050066 [ 14920 ] {bb2eeaef-2449-4fce-85ec-9bce874dec47} executeQuery: Code: 36. DB::Exception: Center (id 18446744073709551615) is not valid in function s2CapContains: In scope SELECT s2CapContains(toUInt64(-1), -1., toUInt64(-1)). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44810) (comment: 01854_s2_cap_contains.sql) (in query: select s2CapContains(toUInt64(-1), -1.0, toUInt64(-1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001b866453 4. DB::(anonymous namespace)::FunctionS2CapContains::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021546f3c 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:13:35.050298 [ 14920 ] {bb2eeaef-2449-4fce-85ec-9bce874dec47} TCPHandler: Code: 36. DB::Exception: Center (id 18446744073709551615) is not valid in function s2CapContains: In scope SELECT s2CapContains(toUInt64(-1), -1., toUInt64(-1)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001b866453 4. DB::(anonymous namespace)::FunctionS2CapContains::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021546f3c 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:13:35.059590 [ 14920 ] {43be437d-3485-4797-86d4-3038d5c4680d} executeQuery: Code: 36. DB::Exception: Center (id 18446744073709551615) is not valid in function s2CapContains: In scope SELECT s2CapContains(toUInt64(-1), 9999.9999, toUInt64(-1)). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44810) (comment: 01854_s2_cap_contains.sql) (in query: select s2CapContains(toUInt64(-1), 9999.9999, toUInt64(-1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001b866453 4. DB::(anonymous namespace)::FunctionS2CapContains::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021546f3c 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:13:35.064413 [ 14920 ] {43be437d-3485-4797-86d4-3038d5c4680d} TCPHandler: Code: 36. DB::Exception: Center (id 18446744073709551615) is not valid in function s2CapContains: In scope SELECT s2CapContains(toUInt64(-1), 9999.9999, toUInt64(-1)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001b866453 4. DB::(anonymous namespace)::FunctionS2CapContains::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021546f3c 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:13:36.516112 [ 48631 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::1]:45520). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:36.917049 [ 23590 ] {d78beb82-0122-498f-9e70-195031a0862d} executeQuery: Code: 42. DB::Exception: Map combinator takes only one map argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:45550) (comment: 01852_map_combinator.sql) (in query: select sumMap(map(1,2), 1, 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000028ea1f55 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7c3d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:36.917288 [ 23590 ] {d78beb82-0122-498f-9e70-195031a0862d} TCPHandler: Code: 42. DB::Exception: Map combinator takes only one map argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000028ea1f55 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7c3d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:36.919458 [ 23590 ] {0ca4d445-c98c-4275-adeb-4c562da4eded} executeQuery: Code: 42. DB::Exception: Map combinator takes only one map argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:45550) (comment: 01852_map_combinator.sql) (in query: select sumMap(map(1,2), map(1,3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000028ea1f55 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7c3d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:36.919568 [ 23590 ] {0ca4d445-c98c-4275-adeb-4c562da4eded} TCPHandler: Code: 42. DB::Exception: Map combinator takes only one map argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000028ea1f55 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7c3d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:36.942748 [ 23590 ] {1ec9f64d-69ae-413e-a423-6a2606a54309} executeQuery: Code: 43. DB::Exception: Aggregation 'avgMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:45550) (comment: 01852_map_combinator.sql) (in query: -- array and tuple arguments select avgMap([1,1,1], [2,2,2]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:454: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028eac023 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:36.942973 [ 23590 ] {1ec9f64d-69ae-413e-a423-6a2606a54309} TCPHandler: Code: 43. DB::Exception: Aggregation 'avgMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:454: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028eac023 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:36.966187 [ 23590 ] {7229a569-dc31-4602-b10a-1ec5df489e71} executeQuery: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:45550) (comment: 01852_map_combinator.sql) (in query: select minMap((1,1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000028ea1e5d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7c3d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:36.966421 [ 23590 ] {7229a569-dc31-4602-b10a-1ec5df489e71} TCPHandler: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000028ea1e5d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7c3d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:36.968551 [ 23590 ] {3a0463de-524c-4003-817e-e0c7522b0de2} executeQuery: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:45550) (comment: 01852_map_combinator.sql) (in query: select minMap(([1,1,1],1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000028ea1e5d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7c3d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:36.968678 [ 23590 ] {3a0463de-524c-4003-817e-e0c7522b0de2} TCPHandler: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000028ea1e5d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7c3d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:36.970143 [ 23590 ] {0fecccb6-66ce-4662-9c16-77efc959f14f} executeQuery: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:45550) (comment: 01852_map_combinator.sql) (in query: select minMap([1,1,1],1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000028ea1e5d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7c3d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:36.970255 [ 23590 ] {0fecccb6-66ce-4662-9c16-77efc959f14f} TCPHandler: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000028ea1e5d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7c3d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:36.971649 [ 23590 ] {dd4a53da-9c08-4987-8195-9fc2018689db} executeQuery: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:45550) (comment: 01852_map_combinator.sql) (in query: select minMap([1,1,1]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000028ea1e5d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7c3d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:36.971748 [ 23590 ] {dd4a53da-9c08-4987-8195-9fc2018689db} TCPHandler: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000028ea1e5d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7c3d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:36.973166 [ 23590 ] {26011564-b18d-4757-b7d4-28d13f6a2082} executeQuery: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:45550) (comment: 01852_map_combinator.sql) (in query: select minMap(([1,1,1]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000028ea1e5d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7c3d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:36.973287 [ 23590 ] {26011564-b18d-4757-b7d4-28d13f6a2082} TCPHandler: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000028ea1e5d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7c3d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:37.048510 [ 48631 ] {32bd9d73-07ec-41d1-8c71-a040cc077984} executeQuery: Code: 47. DB::Exception: JOIN test_x8gkuwq0.v1 AS t1 ALL INNER JOIN test_x8gkuwq0.v1 AS t2 USING (id) ALL INNER JOIN test_x8gkuwq0.v1 AS t3 USING (value) using identifier 'value' cannot be resolved from left table expression. In scope SELECT * FROM v1 AS t1 INNER JOIN v1 AS t2 USING (id) INNER JOIN v1 AS t3 USING (value). (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:45608) (comment: 01852_multiple_joins_with_union_join.sql) (in query: SELECT * FROM v1 AS t1 JOIN v1 AS t2 USING (id) JOIN v1 AS t3 USING (value);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x0000000030925061 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308e0b18 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:37.048743 [ 48631 ] {32bd9d73-07ec-41d1-8c71-a040cc077984} TCPHandler: Code: 47. DB::Exception: JOIN test_x8gkuwq0.v1 AS t1 ALL INNER JOIN test_x8gkuwq0.v1 AS t2 USING (id) ALL INNER JOIN test_x8gkuwq0.v1 AS t3 USING (value) using identifier 'value' cannot be resolved from left table expression. In scope SELECT * FROM v1 AS t1 INNER JOIN v1 AS t2 USING (id) INNER JOIN v1 AS t3 USING (value). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x0000000030925061 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308e0b18 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:37.348079 [ 23590 ] {76177037-609e-444f-9cf2-e602ada9d231} executeQuery: Code: 25. DB::Exception: Invalid escape sequence at the end of LIKE pattern '\': In scope SELECT '\\' LIKE '\\'. (CANNOT_PARSE_ESCAPE_SEQUENCE) (version 24.3.12.76.altinitystable) (from [::1]:45650) (comment: 01847_bad_like.sql) (in query: SELECT '\\' LIKE '\\';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001cea75fb 4. ./build_docker/./src/Common/likePatternToRegexp.cpp:61: DB::likePatternToRegexp(std::basic_string_view>) @ 0x00000000246f5c31 5. OptimizedRegularExpression DB::Regexps::createRegexp(String const&) @ 0x000000001e9c9eec 6. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x000000001e9c930e 7. DB::MatchImpl::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001e9c4d10 8. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e9c2af9 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:13:37.348323 [ 23590 ] {76177037-609e-444f-9cf2-e602ada9d231} TCPHandler: Code: 25. DB::Exception: Invalid escape sequence at the end of LIKE pattern '\': In scope SELECT '\\' LIKE '\\'. (CANNOT_PARSE_ESCAPE_SEQUENCE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001cea75fb 4. ./build_docker/./src/Common/likePatternToRegexp.cpp:61: DB::likePatternToRegexp(std::basic_string_view>) @ 0x00000000246f5c31 5. OptimizedRegularExpression DB::Regexps::createRegexp(String const&) @ 0x000000001e9c9eec 6. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x000000001e9c930e 7. DB::MatchImpl::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001e9c4d10 8. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e9c2af9 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:13:38.759348 [ 23611 ] {294f7938-35e9-4ab8-bf08-0817afd3224c} executeQuery: Code: 6. DB::Exception: Cannot parse string '1\'4' as UInt32: syntax error at position 1 (parsed just '1'). Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST('1\'4', 'UInt32'). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:45856) (comment: 01852_cast_operator_bad_cases.sh) (in query: SELECT '1''4'::UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182d1e60 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182c966f 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 17. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 19. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 24. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 30. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 2025.03.05 21:13:38.759707 [ 23611 ] {294f7938-35e9-4ab8-bf08-0817afd3224c} TCPHandler: Code: 6. DB::Exception: Cannot parse string '1\'4' as UInt32: syntax error at position 1 (parsed just '1'). Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST('1\'4', 'UInt32'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182d1e60 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182c966f 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 17. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 19. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 24. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 30. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 2025.03.05 21:13:40.221832 [ 23606 ] {21d29a1a-0a7f-4c9b-a860-f16cfda01f07} executeQuery: Code: 60. DB::Exception: Table default.non_existing_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:48498) (in query: INSERT INTO non_existing_table SELECT col1, initializeAggregation('argMaxState', col2, insertTime) as col2, now() as insertTime FROM input('col1 String, col2 Array(Float64)') FORMAT CSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 12. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:40.222184 [ 23606 ] {21d29a1a-0a7f-4c9b-a860-f16cfda01f07} DynamicQueryHandler: Code: 60. DB::Exception: Table default.non_existing_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 12. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:41.402295 [ 48603 ] {8c4b5a6b-5c9e-448f-b3bc-58136a66554e} executeQuery: Code: 122. DB::Exception: Data in Object has ambiguous paths: 'key_0.key_11' and 'key_0.key_5'. Paths have prefixes matched by names, but different in structure. (INCOMPATIBLE_COLUMNS) (version 24.3.12.76.altinitystable) (from [::1]:37640) (comment: 01825_type_json_14.sql) (in query: INSERT INTO t_json_14 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/DataTypes/ObjectUtils.cpp:0: DB::checkObjectHasNoAmbiguosPaths(std::vector> const&) @ 0x000000002f5625a4 5. ./build_docker/./src/DataTypes/ObjectUtils.cpp:0: DB::getLeastCommonTypeForDynamicColumnsImpl(std::shared_ptr const&, std::vector, std::allocator>> const&, bool) @ 0x000000002f563350 6. ./build_docker/./src/DataTypes/ObjectUtils.cpp:457: DB::getLeastCommonTypeForDynamicColumns(std::shared_ptr const&, std::vector, std::allocator>> const&, bool) @ 0x000000002f561d80 7. ./build_docker/./src/DataTypes/ObjectUtils.cpp:260: DB::convertDynamicColumnsToTuples(DB::Block&, std::shared_ptr const&) @ 0x000000002f55fdff 8. ./build_docker/./src/Storages/StorageMemory.cpp:0: DB::MemorySink::consume(DB::Chunk) @ 0x000000003230895d 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 15. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:41.402529 [ 48603 ] {8c4b5a6b-5c9e-448f-b3bc-58136a66554e} TCPHandler: Code: 122. DB::Exception: Data in Object has ambiguous paths: 'key_0.key_11' and 'key_0.key_5'. Paths have prefixes matched by names, but different in structure. (INCOMPATIBLE_COLUMNS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/DataTypes/ObjectUtils.cpp:0: DB::checkObjectHasNoAmbiguosPaths(std::vector> const&) @ 0x000000002f5625a4 5. ./build_docker/./src/DataTypes/ObjectUtils.cpp:0: DB::getLeastCommonTypeForDynamicColumnsImpl(std::shared_ptr const&, std::vector, std::allocator>> const&, bool) @ 0x000000002f563350 6. ./build_docker/./src/DataTypes/ObjectUtils.cpp:457: DB::getLeastCommonTypeForDynamicColumns(std::shared_ptr const&, std::vector, std::allocator>> const&, bool) @ 0x000000002f561d80 7. ./build_docker/./src/DataTypes/ObjectUtils.cpp:260: DB::convertDynamicColumnsToTuples(DB::Block&, std::shared_ptr const&) @ 0x000000002f55fdff 8. ./build_docker/./src/Storages/StorageMemory.cpp:0: DB::MemorySink::consume(DB::Chunk) @ 0x000000003230895d 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 15. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:41.519650 [ 23586 ] {58fde948-e67b-4b34-a00a-5b6f1a4caefc} executeQuery: Code: 122. DB::Exception: Data in Object has ambiguous paths: 'arr' and 'arr.k33'. (INCOMPATIBLE_COLUMNS) (version 24.3.12.76.altinitystable) (from [::1]:37656) (comment: 01825_type_json_insert_select.sql) (in query: INSERT INTO type_json_dst SELECT * FROM type_json_src WHERE id = 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/DataTypes/ObjectUtils.cpp:0: DB::checkObjectHasNoAmbiguosPaths(std::vector> const&) @ 0x000000002f562489 5. ./build_docker/./src/DataTypes/ObjectUtils.cpp:0: DB::getLeastCommonTypeForDynamicColumnsImpl(std::shared_ptr const&, std::vector, std::allocator>> const&, bool) @ 0x000000002f563350 6. ./build_docker/./src/DataTypes/ObjectUtils.cpp:457: DB::getLeastCommonTypeForDynamicColumns(std::shared_ptr const&, std::vector, std::allocator>> const&, bool) @ 0x000000002f561d80 7. ./build_docker/./src/DataTypes/ObjectUtils.cpp:260: DB::convertDynamicColumnsToTuples(DB::Block&, std::shared_ptr const&) @ 0x000000002f55fdff 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:66: DB::MergeTreeSink::consume(DB::Chunk) @ 0x00000000330dfe59 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 18. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:41.519848 [ 23586 ] {58fde948-e67b-4b34-a00a-5b6f1a4caefc} TCPHandler: Code: 122. DB::Exception: Data in Object has ambiguous paths: 'arr' and 'arr.k33'. (INCOMPATIBLE_COLUMNS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/DataTypes/ObjectUtils.cpp:0: DB::checkObjectHasNoAmbiguosPaths(std::vector> const&) @ 0x000000002f562489 5. ./build_docker/./src/DataTypes/ObjectUtils.cpp:0: DB::getLeastCommonTypeForDynamicColumnsImpl(std::shared_ptr const&, std::vector, std::allocator>> const&, bool) @ 0x000000002f563350 6. ./build_docker/./src/DataTypes/ObjectUtils.cpp:457: DB::getLeastCommonTypeForDynamicColumns(std::shared_ptr const&, std::vector, std::allocator>> const&, bool) @ 0x000000002f561d80 7. ./build_docker/./src/DataTypes/ObjectUtils.cpp:260: DB::convertDynamicColumnsToTuples(DB::Block&, std::shared_ptr const&) @ 0x000000002f55fdff 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:66: DB::MergeTreeSink::consume(DB::Chunk) @ 0x00000000330dfe59 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 18. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:42.771382 [ 22863 ] {5bd6f0e1-3c83-4c89-a7c4-cd8a80482579} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.3.12.76.altinitystable) (from [::1]:37894) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:42.771609 [ 22863 ] {5bd6f0e1-3c83-4c89-a7c4-cd8a80482579} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageFile.cpp:1573: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000321f1b1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:44.074250 [ 22863 ] {8bba11a4-ac89-46ac-b326-a5c464b9bd00} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 24.3.12.76.altinitystable) (from [::1]:38076) (comment: 01822_async_read_from_socket_crash.sh) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:44.076353 [ 22863 ] {8bba11a4-ac89-46ac-b326-a5c464b9bd00} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:44.182413 [ 48606 ] {dfa6bc56-7110-46c1-8efb-2b4d88f8510a} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37226). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:37226) (comment: 01822_async_read_from_socket_crash.sh) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5be4 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:44.182836 [ 48606 ] {dfa6bc56-7110-46c1-8efb-2b4d88f8510a} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37226). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:44.182878 [ 48606 ] {dfa6bc56-7110-46c1-8efb-2b4d88f8510a} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37226). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5be4 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:44.183066 [ 48606 ] {dfa6bc56-7110-46c1-8efb-2b4d88f8510a} TCPHandler: Client has gone away. 2025.03.05 21:13:44.569579 [ 22863 ] {b41fefd3-3798-4340-bf1f-f20d43f9bb21} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 24.3.12.76.altinitystable) (from [::1]:38220) (comment: 01822_async_read_from_socket_crash.sh) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:44.569971 [ 22863 ] {b41fefd3-3798-4340-bf1f-f20d43f9bb21} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:44.685991 [ 48611 ] {f37d2d9d-54d8-47f4-a844-26999d17aff9} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37236). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:37236) (comment: 01822_async_read_from_socket_crash.sh) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:44.686396 [ 48611 ] {f37d2d9d-54d8-47f4-a844-26999d17aff9} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37236). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:44.686437 [ 48611 ] {f37d2d9d-54d8-47f4-a844-26999d17aff9} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37236). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:44.686570 [ 48611 ] {f37d2d9d-54d8-47f4-a844-26999d17aff9} TCPHandler: Client has gone away. 2025.03.05 21:13:45.080300 [ 23610 ] {723f0b4f-5c57-481b-9672-0b18fd521273} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 24.3.12.76.altinitystable) (from [::1]:38338) (comment: 01822_async_read_from_socket_crash.sh) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:45.080885 [ 23610 ] {723f0b4f-5c57-481b-9672-0b18fd521273} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:45.180097 [ 48611 ] {4328aaba-7fab-4303-a0c9-1ea1255f0ea4} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37244). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:37244) (comment: 01822_async_read_from_socket_crash.sh) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:45.180573 [ 48611 ] {4328aaba-7fab-4303-a0c9-1ea1255f0ea4} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37244). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:45.180622 [ 48611 ] {4328aaba-7fab-4303-a0c9-1ea1255f0ea4} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37244). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:45.180791 [ 48611 ] {4328aaba-7fab-4303-a0c9-1ea1255f0ea4} TCPHandler: Client has gone away. 2025.03.05 21:13:45.577336 [ 48611 ] {d8184d81-19bb-4f17-9a54-c379a539f457} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 24.3.12.76.altinitystable) (from [::1]:38442) (comment: 01822_async_read_from_socket_crash.sh) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:45.577952 [ 48611 ] {d8184d81-19bb-4f17-9a54-c379a539f457} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:45.677020 [ 23610 ] {aead41fd-197e-48df-85bc-97fcf8216e1e} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37246). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:37246) (comment: 01822_async_read_from_socket_crash.sh) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:45.677468 [ 23610 ] {aead41fd-197e-48df-85bc-97fcf8216e1e} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37246). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:45.677591 [ 23610 ] {aead41fd-197e-48df-85bc-97fcf8216e1e} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37246). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:45.677769 [ 23610 ] {aead41fd-197e-48df-85bc-97fcf8216e1e} TCPHandler: Client has gone away. 2025.03.05 21:13:46.071578 [ 23642 ] {e4339b1b-e3d4-40b5-9151-ff75cf873442} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 24.3.12.76.altinitystable) (from [::1]:38550) (comment: 01822_async_read_from_socket_crash.sh) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:46.073353 [ 23642 ] {e4339b1b-e3d4-40b5-9151-ff75cf873442} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:46.169521 [ 48581 ] {50438f68-d4c3-44cc-8bba-4c32a1983055} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37250). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:37250) (comment: 01822_async_read_from_socket_crash.sh) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:46.169972 [ 48581 ] {50438f68-d4c3-44cc-8bba-4c32a1983055} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37250). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.170029 [ 48581 ] {50438f68-d4c3-44cc-8bba-4c32a1983055} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37250). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:46.170237 [ 48581 ] {50438f68-d4c3-44cc-8bba-4c32a1983055} TCPHandler: Client has gone away. 2025.03.05 21:13:46.190222 [ 34946 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.190388 [ 34946 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.198331 [ 34946 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.198451 [ 34946 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.206392 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.206516 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.215069 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.215296 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.225269 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.225417 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.233974 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.234197 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.244945 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.245198 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.256075 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.256330 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.268373 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.268597 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.277778 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.277990 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.287700 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.287914 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.297270 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.297485 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.308442 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.308877 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.318032 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.318233 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.327994 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.328181 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.340512 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.340667 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.350272 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.350400 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.361642 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.361834 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.370863 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.371021 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.382969 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.383094 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.391609 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.391734 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.400042 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.400227 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.408435 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.408585 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.416563 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.416745 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.426183 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.426347 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.435376 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.435518 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.443912 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.444082 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.455180 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.455344 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.465677 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.465833 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.475351 [ 48581 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.475546 [ 48581 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.485351 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.485517 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.494607 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.494773 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.504836 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.504999 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.514200 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.514433 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.522893 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.523064 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.530924 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.531078 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.539647 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.539911 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.548795 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.549014 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.557002 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.557200 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.565562 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.565738 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.570371 [ 48605 ] {66ad295e-1f7a-4572-9011-8d935d196e17} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.3:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 24.3.12.76.altinitystable) (from [::1]:38608) (comment: 01822_async_read_from_socket_crash.sh) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:46.570780 [ 48605 ] {66ad295e-1f7a-4572-9011-8d935d196e17} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.3:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:46.574661 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.574823 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.585043 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.585216 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.594527 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.594682 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.604116 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.604308 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.614260 [ 48605 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.614414 [ 48605 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.623480 [ 48605 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.623643 [ 48605 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.633685 [ 48605 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.633858 [ 48605 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.642931 [ 48605 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.643083 [ 48605 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.653751 [ 48605 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.653964 [ 48605 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.663381 [ 48605 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.663586 [ 48605 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.670088 [ 23628 ] {f2d856ad-64e2-4833-be19-c3b5afc7476a} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:52354). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:52354) (comment: 01822_async_read_from_socket_crash.sh) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:46.670522 [ 23628 ] {f2d856ad-64e2-4833-be19-c3b5afc7476a} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:52354). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.670585 [ 23628 ] {f2d856ad-64e2-4833-be19-c3b5afc7476a} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:52354). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:46.670766 [ 23628 ] {f2d856ad-64e2-4833-be19-c3b5afc7476a} TCPHandler: Client has gone away. 2025.03.05 21:13:46.674104 [ 48605 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.674339 [ 48605 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.683621 [ 48605 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.683784 [ 48605 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.693344 [ 48605 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.693512 [ 48605 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.701819 [ 48605 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.701968 [ 48605 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.712384 [ 48605 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.712534 [ 48605 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.721838 [ 48605 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.722001 [ 48605 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.730945 [ 48605 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.731099 [ 48605 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.740812 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.740985 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.750404 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.750670 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.759633 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.759864 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.768414 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.768659 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.779450 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.779700 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.789092 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.789343 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.799610 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.799759 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.810193 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.810420 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.820243 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.820411 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.829588 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.829770 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.840009 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.840189 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.852281 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.852467 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.860231 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.860387 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.869721 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.869880 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.878145 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.878330 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.889044 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.889269 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.899020 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.899322 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.912790 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.912975 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.923349 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.923537 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.933221 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.933424 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.943735 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.943928 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.958262 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.958430 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.973717 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.977433 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.988749 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:46.989117 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.002911 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.003172 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.013362 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.013607 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.022614 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.022778 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.030784 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.031000 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.041303 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.041479 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.050042 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.050265 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.058978 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.060667 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.061073 [ 5753 ] {c9d5f701-c68f-45af-b282-55f405709b5d} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.3:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 24.3.12.76.altinitystable) (from [::1]:38710) (comment: 01822_async_read_from_socket_crash.sh) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:47.062484 [ 5753 ] {c9d5f701-c68f-45af-b282-55f405709b5d} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.3:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:47.069102 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.069256 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.079006 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.079167 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.087947 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.088103 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.097385 [ 14920 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.097535 [ 14920 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.106684 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.106897 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.131438 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.131636 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.140952 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.141199 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.151862 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.153017 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.156038 [ 23642 ] {2eb74752-6427-4fad-ba72-91324707177e} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:52368). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:52368) (comment: 01822_async_read_from_socket_crash.sh) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5be4 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:47.158838 [ 23642 ] {2eb74752-6427-4fad-ba72-91324707177e} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:52368). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.158906 [ 23642 ] {2eb74752-6427-4fad-ba72-91324707177e} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:52368). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5be4 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:47.160871 [ 23642 ] {2eb74752-6427-4fad-ba72-91324707177e} TCPHandler: Client has gone away. 2025.03.05 21:13:47.164836 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.171259 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.186352 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.187654 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.200407 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.200634 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.214732 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.220104 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.231289 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.231476 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.242827 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.243099 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.257688 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.258432 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.268627 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.269103 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.280548 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.282386 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.293121 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.293351 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.301138 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.301303 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.309278 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.309437 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.319039 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.319234 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.327295 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.327483 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.336072 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.336267 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.345027 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.345278 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.355059 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.355258 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.364085 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.364283 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.373093 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.373330 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.381431 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.381657 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.390581 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.390879 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.399505 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.399641 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.408578 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.408961 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.417000 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.417134 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.424910 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.425094 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.433929 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.434080 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.442514 [ 48626 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.442674 [ 48626 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.451952 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.452256 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.461048 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.461269 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.470274 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.470436 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.479770 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.479959 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.488843 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.488991 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.497544 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.497682 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.507894 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.508089 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.516390 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.516595 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.525881 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.526069 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.535776 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.536008 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.545546 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.545766 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.555417 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.555618 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.565374 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.565567 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.574562 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.574733 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.583808 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.583994 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.593370 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.593526 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.597906 [ 14920 ] {9abfb486-b1bb-4448-9388-c2c0a0a871ae} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 24.3.12.76.altinitystable) (from [::1]:38834) (comment: 01822_async_read_from_socket_crash.sh) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:47.598400 [ 14920 ] {9abfb486-b1bb-4448-9388-c2c0a0a871ae} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:47.603601 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.603760 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.614904 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.617211 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.633080 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.633283 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.646214 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.646521 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.656516 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.656830 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.666584 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.666909 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.675717 [ 23587 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.675900 [ 23587 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.686670 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.686830 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.696355 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.696581 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.697622 [ 22858 ] {61e885a9-1ca8-4c11-a74b-af559e288f7f} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37300). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:37300) (comment: 01822_async_read_from_socket_crash.sh) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5be4 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:47.698046 [ 22858 ] {61e885a9-1ca8-4c11-a74b-af559e288f7f} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37300). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.698100 [ 22858 ] {61e885a9-1ca8-4c11-a74b-af559e288f7f} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37300). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5be4 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:47.698260 [ 22858 ] {61e885a9-1ca8-4c11-a74b-af559e288f7f} TCPHandler: Client has gone away. 2025.03.05 21:13:47.705256 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.705416 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.715001 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.715147 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.723782 [ 5753 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 12. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.723950 [ 5753 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000333cadca 7. ./build_docker/./src/Server/HTTPHandler.cpp:550: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000333ce4a4 8. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:47.879460 [ 23498 ] {d54d3da1-2c99-43ec-8f9b-30b659f533bd} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 9.00, current rows: 10.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:38932) (comment: 01801_approx_total_rows_mergetree_reverse.sql) (in query: select * from data_01801 where key = 0 order by key settings max_rows_to_read=9 format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f3d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:47.879596 [ 23498 ] {d54d3da1-2c99-43ec-8f9b-30b659f533bd} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 9.00, current rows: 10.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f3d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:47.883037 [ 23498 ] {34a2e4fa-0be6-4168-b93d-66a0362088d2} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 9.00, current rows: 10.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InReverseOrder). (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:38932) (comment: 01801_approx_total_rows_mergetree_reverse.sql) (in query: select * from data_01801 where key = 0 order by key desc settings max_rows_to_read=9 format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f3d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:47.883156 [ 23498 ] {34a2e4fa-0be6-4168-b93d-66a0362088d2} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 9.00, current rows: 10.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InReverseOrder). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f3d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:48.094460 [ 48601 ] {3564af8c-d070-49b2-8635-8ff0308bd681} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 24.3.12.76.altinitystable) (from [::1]:38930) (comment: 01822_async_read_from_socket_crash.sh) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:48.097289 [ 48601 ] {3564af8c-d070-49b2-8635-8ff0308bd681} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:48.191792 [ 23622 ] {112922b8-cf09-45db-bf6f-c63f15497eac} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37326). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:37326) (comment: 01822_async_read_from_socket_crash.sh) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5be4 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:48.192335 [ 23622 ] {112922b8-cf09-45db-bf6f-c63f15497eac} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37326). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:48.192411 [ 23622 ] {112922b8-cf09-45db-bf6f-c63f15497eac} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37326). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5be4 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:48.192602 [ 23622 ] {112922b8-cf09-45db-bf6f-c63f15497eac} TCPHandler: Client has gone away. 2025.03.05 21:13:48.610971 [ 23587 ] {169a0d04-474d-43b0-b6db-fb01503c560d} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 24.3.12.76.altinitystable) (from [::1]:39014) (comment: 01822_async_read_from_socket_crash.sh) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:48.611514 [ 23587 ] {169a0d04-474d-43b0-b6db-fb01503c560d} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c627 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:48.710131 [ 23498 ] {63fe0c65-b2a1-44ac-8b15-fc41a6d0035e} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37354). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:37354) (comment: 01822_async_read_from_socket_crash.sh) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5be4 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:48.710572 [ 23498 ] {63fe0c65-b2a1-44ac-8b15-fc41a6d0035e} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37354). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:48.710622 [ 23498 ] {63fe0c65-b2a1-44ac-8b15-fc41a6d0035e} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37354). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5be4 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:48.710803 [ 23498 ] {63fe0c65-b2a1-44ac-8b15-fc41a6d0035e} TCPHandler: Client has gone away. 2025.03.05 21:13:49.654842 [ 23611 ] {46d1267c-7dff-4fca-82fe-1af405635be4} executeQuery: Code: 128. DB::Exception: Function mapPopulateSeries too large array size in the result: In scope SELECT mapPopulateSeries([-9223372036854775808, toUInt32(2)], [toUInt32(1023), -1]). (TOO_LARGE_ARRAY_SIZE) (version 24.3.12.76.altinitystable) (from [::1]:47594) (comment: 01777_map_populate_series_ubsan.sql) (in query: -- Should correctly throw exception about overflow: SELECT mapPopulateSeries([-9223372036854775808, toUInt32(2)], [toUInt32(1023), -1]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::FunctionMapPopulateSeries::executeImplTyped(COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::mutable_ptr, COW::mutable_ptr, COW::mutable_ptr) const @ 0x00000000244e1e86 5. auto DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator(), DB::DataTypeNumber>>(auto const&) const @ 0x00000000244e0bed 6. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002424dda4 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:13:49.655093 [ 23611 ] {46d1267c-7dff-4fca-82fe-1af405635be4} TCPHandler: Code: 128. DB::Exception: Function mapPopulateSeries too large array size in the result: In scope SELECT mapPopulateSeries([-9223372036854775808, toUInt32(2)], [toUInt32(1023), -1]). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::FunctionMapPopulateSeries::executeImplTyped(COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::mutable_ptr, COW::mutable_ptr, COW::mutable_ptr) const @ 0x00000000244e1e86 5. auto DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator(), DB::DataTypeNumber>>(auto const&) const @ 0x00000000244e0bed 6. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002424dda4 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:13:49.918638 [ 23597 ] {d53a17d1-2526-47e6-a4ad-fcf7c490d46f} executeQuery: Code: 6. DB::Exception: Neither IPv4 nor IPv6 address: 'unparsable': In scope SELECT isIPAddressInRange('unparsable', '127.0.0.0/8'). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:47606) (comment: 01774_ip_address_in_range.sql) (in query: SELECT isIPAddressInRange('unparsable', '127.0.0.0/8');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001cea75fb 4. (anonymous namespace)::IPAddressVariant::IPAddressVariant(std::basic_string_view>) @ 0x000000001d7f215d 5. DB::FunctionIsIPAddressContainedIn::executeImpl(DB::ColumnConst const&, DB::ColumnConst const&, unsigned long) @ 0x000000001d7f3d0f 6. DB::FunctionIsIPAddressContainedIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d7f3588 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:13:49.918849 [ 23597 ] {d53a17d1-2526-47e6-a4ad-fcf7c490d46f} TCPHandler: Code: 6. DB::Exception: Neither IPv4 nor IPv6 address: 'unparsable': In scope SELECT isIPAddressInRange('unparsable', '127.0.0.0/8'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001cea75fb 4. (anonymous namespace)::IPAddressVariant::IPAddressVariant(std::basic_string_view>) @ 0x000000001d7f215d 5. DB::FunctionIsIPAddressContainedIn::executeImpl(DB::ColumnConst const&, DB::ColumnConst const&, unsigned long) @ 0x000000001d7f3d0f 6. DB::FunctionIsIPAddressContainedIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d7f3588 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:13:49.951342 [ 23597 ] {76361319-c0cf-43a2-8738-0219cbe9b125} executeQuery: Code: 6. DB::Exception: The text does not contain '/': unparsable: In scope SELECT isIPAddressInRange('127.0.0.1', 'unparsable'). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:47606) (comment: 01774_ip_address_in_range.sql) (in query: SELECT isIPAddressInRange('127.0.0.1', 'unparsable');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. (anonymous namespace)::parseIPWithCIDR(std::basic_string_view>) @ 0x000000001d7f2364 5. DB::FunctionIsIPAddressContainedIn::executeImpl(DB::ColumnConst const&, DB::ColumnConst const&, unsigned long) @ 0x000000001d7f3d5f 6. DB::FunctionIsIPAddressContainedIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d7f3588 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:13:49.951569 [ 23597 ] {76361319-c0cf-43a2-8738-0219cbe9b125} TCPHandler: Code: 6. DB::Exception: The text does not contain '/': unparsable: In scope SELECT isIPAddressInRange('127.0.0.1', 'unparsable'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. (anonymous namespace)::parseIPWithCIDR(std::basic_string_view>) @ 0x000000001d7f2364 5. DB::FunctionIsIPAddressContainedIn::executeImpl(DB::ColumnConst const&, DB::ColumnConst const&, unsigned long) @ 0x000000001d7f3d5f 6. DB::FunctionIsIPAddressContainedIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d7f3588 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:13:49.980087 [ 23597 ] {f8236058-ad9a-470a-90c7-95237c92e9a1} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(100, '127.0.0.0/8'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:47606) (comment: 01774_ip_address_in_range.sql) (in query: SELECT isIPAddressInRange(100, '127.0.0.0/8');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001d7f393d 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:49.980331 [ 23597 ] {f8236058-ad9a-470a-90c7-95237c92e9a1} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(100, '127.0.0.0/8'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001d7f393d 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:49.982153 [ 23597 ] {c86adf24-b158-4757-b586-5df928691dfb} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(NULL, '127.0.0.0/8'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:47606) (comment: 01774_ip_address_in_range.sql) (in query: SELECT isIPAddressInRange(NULL, '127.0.0.0/8');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001d7f393d 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:49.982274 [ 23597 ] {c86adf24-b158-4757-b586-5df928691dfb} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(NULL, '127.0.0.0/8'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001d7f393d 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:49.983618 [ 23597 ] {bbb2dbd4-1d21-4f43-a064-41993a1fc15f} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(CAST(NULL, 'Nullable(String)'), '127.0.0.0/8'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:47606) (comment: 01774_ip_address_in_range.sql) (in query: SELECT isIPAddressInRange(CAST(NULL, 'Nullable(String)'), '127.0.0.0/8');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001d7f393d 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:49.983723 [ 23597 ] {bbb2dbd4-1d21-4f43-a064-41993a1fc15f} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(CAST(NULL, 'Nullable(String)'), '127.0.0.0/8'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001d7f393d 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:49.985053 [ 23597 ] {4fb5b214-71f5-4a8f-956d-2b53fbb0d2f1} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange('127.0.0.1', 100). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:47606) (comment: 01774_ip_address_in_range.sql) (in query: SELECT isIPAddressInRange('127.0.0.1', 100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001d7f393d 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:49.985147 [ 23597 ] {4fb5b214-71f5-4a8f-956d-2b53fbb0d2f1} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange('127.0.0.1', 100). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001d7f393d 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:49.986301 [ 23597 ] {421c2a05-dff3-4908-af0c-805c9ee9faee} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(100, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:47606) (comment: 01774_ip_address_in_range.sql) (in query: SELECT isIPAddressInRange(100, NULL);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001d7f393d 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:49.986394 [ 23597 ] {421c2a05-dff3-4908-af0c-805c9ee9faee} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(100, NULL). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001d7f393d 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:49.987662 [ 23597 ] {1326f48f-b8f5-4cc7-88b9-954d605d7ae6} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope WITH arrayJoin([NULL, NULL, NULL, NULL]) AS prefix SELECT isIPAddressInRange([NULL, NULL, 0, 255, 0], prefix). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:47606) (comment: 01774_ip_address_in_range.sql) (in query: WITH arrayJoin([NULL, NULL, NULL, NULL]) AS prefix SELECT isIPAddressInRange([NULL, NULL, 0, 255, 0], prefix);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001d7f393d 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:49.987762 [ 23597 ] {1326f48f-b8f5-4cc7-88b9-954d605d7ae6} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope WITH arrayJoin([NULL, NULL, NULL, NULL]) AS prefix SELECT isIPAddressInRange([NULL, NULL, 0, 255, 0], prefix). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionIsIPAddressContainedIn::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001d7f393d 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:50.315228 [ 23611 ] {e9007b05-45d1-4e19-85d3-e4cd0ec5f330} executeQuery: Code: 184. DB::Exception: Aggregate function avg(number) AS number is found inside another aggregate function in query. (ILLEGAL_AGGREGATION) (version 24.3.12.76.altinitystable) (from [::1]:47780) (comment: 01764_prefer_column_name_to_alias.sql) (in query: SELECT avg(number) AS number, max(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030943593 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000030943817 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093b05e 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:50.315410 [ 23611 ] {e9007b05-45d1-4e19-85d3-e4cd0ec5f330} TCPHandler: Code: 184. DB::Exception: Aggregate function avg(number) AS number is found inside another aggregate function in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030943593 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000030943817 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093b05e 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:50.317561 [ 23611 ] {00ea9663-00aa-48a4-9c32-705d331bd7dc} executeQuery: Code: 184. DB::Exception: Aggregate function sum(x) AS x is found inside another aggregate function in query. (ILLEGAL_AGGREGATION) (version 24.3.12.76.altinitystable) (from [::1]:47780) (comment: 01764_prefer_column_name_to_alias.sql) (in query: SELECT sum(x) AS x, max(x) FROM (SELECT 1 AS x UNION ALL SELECT 2 AS x) t;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030943593 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000030943817 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093b05e 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:50.317668 [ 23611 ] {00ea9663-00aa-48a4-9c32-705d331bd7dc} TCPHandler: Code: 184. DB::Exception: Aggregate function sum(x) AS x is found inside another aggregate function in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030943593 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000030943817 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093b05e 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:50.319074 [ 23611 ] {995f727a-33ca-4d94-8cd5-3d7e81f0ec56} executeQuery: Code: 184. DB::Exception: Aggregate function sum(C1) AS C1 is found inside another aggregate function in query. (ILLEGAL_AGGREGATION) (version 24.3.12.76.altinitystable) (from [::1]:47780) (comment: 01764_prefer_column_name_to_alias.sql) (in query: select sum(C1) as C1, count(C1) as C2 from (select number as C1 from numbers(3)) as ITBL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030943593 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000030943817 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093b05e 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:50.319190 [ 23611 ] {995f727a-33ca-4d94-8cd5-3d7e81f0ec56} TCPHandler: Code: 184. DB::Exception: Aggregate function sum(C1) AS C1 is found inside another aggregate function in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030943593 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000309432f3 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000030943817 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003093b05e 8. ./contrib/llvm-project/libcxx/include/vector:1420: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875961 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:50.622620 [ 23639 ] {1062c2e7-6233-48f2-ac29-6875bfeaa945} StorageDistributed (tt6): Name of remote database is empty. Default database will be used implicitly. 2025.03.05 21:13:50.627362 [ 23639 ] {2370a756-6987-4a56-ad96-71d1da23d235} StorageDistributed (tt7): Name of remote database is empty. Default database will be used implicitly. 2025.03.05 21:13:50.664256 [ 23639 ] {ae798cdb-39dc-4ce3-a754-b76af9ae52d9} executeQuery: Code: 581. DB::Exception: Maximum distributed depth exceeded. (TOO_LARGE_DISTRIBUTED_DEPTH) (version 24.3.12.76.altinitystable) (from [::1]:47900) (comment: 01763_max_distributed_depth.sql) (in query: INSERT INTO tt6 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:131: DB::DistributedSink::DistributedSink(std::shared_ptr, DB::StorageDistributed&, std::shared_ptr const&, std::shared_ptr const&, bool, unsigned long, std::vector> const&) @ 0x000000003293293f 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::DistributedSink* std::construct_at[abi:v15000]&, DB::StorageDistributed&, std::shared_ptr const&, std::shared_ptr&, bool&, DB::SettingFieldNumber&, std::vector>&, DB::DistributedSink*>(DB::DistributedSink*, std::shared_ptr&, DB::StorageDistributed&, std::shared_ptr const&, std::shared_ptr&, bool&, DB::SettingFieldNumber&, std::vector>&) @ 0x00000000321c4cb1 6. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::StorageDistributed&, std::shared_ptr const&, std::shared_ptr&, bool&, DB::SettingFieldNumber&, std::vector>&>(std::allocator, std::shared_ptr&, DB::StorageDistributed&, std::shared_ptr const&, std::shared_ptr&, bool&, DB::SettingFieldNumber&, std::vector>&) @ 0x00000000321c465c 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr&, DB::StorageDistributed&, std::shared_ptr const&, std::shared_ptr&, bool&, DB::SettingFieldNumber&, std::vector>&, void>(std::allocator const&, std::shared_ptr&, DB::StorageDistributed&, std::shared_ptr const&, std::shared_ptr&, bool&, DB::SettingFieldNumber&, std::vector>&) @ 0x00000000321c43e9 8. ./build_docker/./src/Storages/StorageDistributed.cpp:972: DB::StorageDistributed::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000321999ba 9. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 11. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 12. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:710: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000003293ccb0 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x0000000032935ad6 14. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:179: DB::DistributedSink::writeAsync(DB::Block const&) @ 0x0000000032935159 15. ./src/Core/Block.h:25: DB::DistributedSink::consume(DB::Chunk) @ 0x0000000032932f58 16. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 17. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 22. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 23. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000003293cdc1 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x0000000032935ad6 25. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:179: DB::DistributedSink::writeAsync(DB::Block const&) @ 0x0000000032935159 26. ./src/Core/Block.h:25: DB::DistributedSink::consume(DB::Chunk) @ 0x0000000032932f58 27. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 2025.03.05 21:13:50.664461 [ 23639 ] {ae798cdb-39dc-4ce3-a754-b76af9ae52d9} TCPHandler: Code: 581. DB::Exception: Maximum distributed depth exceeded. (TOO_LARGE_DISTRIBUTED_DEPTH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:131: DB::DistributedSink::DistributedSink(std::shared_ptr, DB::StorageDistributed&, std::shared_ptr const&, std::shared_ptr const&, bool, unsigned long, std::vector> const&) @ 0x000000003293293f 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::DistributedSink* std::construct_at[abi:v15000]&, DB::StorageDistributed&, std::shared_ptr const&, std::shared_ptr&, bool&, DB::SettingFieldNumber&, std::vector>&, DB::DistributedSink*>(DB::DistributedSink*, std::shared_ptr&, DB::StorageDistributed&, std::shared_ptr const&, std::shared_ptr&, bool&, DB::SettingFieldNumber&, std::vector>&) @ 0x00000000321c4cb1 6. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::StorageDistributed&, std::shared_ptr const&, std::shared_ptr&, bool&, DB::SettingFieldNumber&, std::vector>&>(std::allocator, std::shared_ptr&, DB::StorageDistributed&, std::shared_ptr const&, std::shared_ptr&, bool&, DB::SettingFieldNumber&, std::vector>&) @ 0x00000000321c465c 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr&, DB::StorageDistributed&, std::shared_ptr const&, std::shared_ptr&, bool&, DB::SettingFieldNumber&, std::vector>&, void>(std::allocator const&, std::shared_ptr&, DB::StorageDistributed&, std::shared_ptr const&, std::shared_ptr&, bool&, DB::SettingFieldNumber&, std::vector>&) @ 0x00000000321c43e9 8. ./build_docker/./src/Storages/StorageDistributed.cpp:972: DB::StorageDistributed::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000321999ba 9. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 11. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 12. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:710: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000003293ccb0 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x0000000032935ad6 14. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:179: DB::DistributedSink::writeAsync(DB::Block const&) @ 0x0000000032935159 15. ./src/Core/Block.h:25: DB::DistributedSink::consume(DB::Chunk) @ 0x0000000032932f58 16. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 17. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 22. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 23. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000003293cdc1 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x0000000032935ad6 25. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:179: DB::DistributedSink::writeAsync(DB::Block const&) @ 0x0000000032935159 26. ./src/Core/Block.h:25: DB::DistributedSink::consume(DB::Chunk) @ 0x0000000032932f58 27. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 2025.03.05 21:13:50.695586 [ 23639 ] {3752dc03-ed0e-4634-a277-17c12f5e6228} executeQuery: Code: 581. DB::Exception: Maximum distributed depth exceeded. (TOO_LARGE_DISTRIBUTED_DEPTH) (version 24.3.12.76.altinitystable) (from [::1]:47900) (comment: 01763_max_distributed_depth.sql) (in query: SELECT * FROM tt6;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:217: DB::ClusterProxy::executeQuery(DB::QueryPlan&, DB::Block const&, DB::QueryProcessingStage::Enum, DB::StorageID const&, std::shared_ptr const&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr, std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, String const&, DB::DistributedSettings const&, std::function (unsigned long)>) @ 0x00000000318f0a11 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 11. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:76: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb48c1 12. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 13. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 19. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 22. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:76: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb48c1 23. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 24. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 28. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 29. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 30. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 2025.03.05 21:13:50.695813 [ 23639 ] {3752dc03-ed0e-4634-a277-17c12f5e6228} TCPHandler: Code: 581. DB::Exception: Maximum distributed depth exceeded. (TOO_LARGE_DISTRIBUTED_DEPTH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:217: DB::ClusterProxy::executeQuery(DB::QueryPlan&, DB::Block const&, DB::QueryProcessingStage::Enum, DB::StorageID const&, std::shared_ptr const&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr, std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, String const&, DB::DistributedSettings const&, std::function (unsigned long)>) @ 0x00000000318f0a11 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 11. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:76: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb48c1 12. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 13. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 19. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 22. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:76: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb48c1 23. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 24. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 28. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 29. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 30. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 2025.03.05 21:13:51.062156 [ 22863 ] {39b2af66-c637-463f-ba47-2337d3bef71b} executeQuery: Code: 153. DB::Exception: Division by the most negative number. (ILLEGAL_DIVISION) (version 24.3.12.76.altinitystable) (from [::1]:47968) (comment: 01760_modulo_negative.sql) (in query: SELECT -number % -9223372036854775808 FROM system.numbers;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::ModuloByConstantImpl::vectorConstant(long const*, long, long*, unsigned long) @ 0x000000001f0366df 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001f49d81b 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001f49cf22 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001f49321f 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001f3bf0ec 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001f3ba36c 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f3b7545 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f3b5ff1 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 19. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 21. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 22. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:13:51.072482 [ 22863 ] {39b2af66-c637-463f-ba47-2337d3bef71b} TCPHandler: Code: 153. DB::Exception: Division by the most negative number. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::ModuloByConstantImpl::vectorConstant(long const*, long, long*, unsigned long) @ 0x000000001f0366df 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001f49d81b 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001f49cf22 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001f49321f 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001f3bf0ec 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001f3ba36c 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f3b7545 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f3b5ff1 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 19. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 21. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 22. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:13:51.348117 [ 22866 ] {6712ec87-7b80-4ab9-815c-5ee98295af84} executeQuery: Code: 507. DB::Exception: Sharding key dummy is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.3.12.76.altinitystable) (from [::1]:48004) (comment: 01757_optimize_skip_unused_shards_limit.sql) (in query: -- in negative select * from dist_01757 where dummy in (0, 1) settings optimize_skip_unused_shards_limit=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fa4a 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:51.348324 [ 22866 ] {6712ec87-7b80-4ab9-815c-5ee98295af84} TCPHandler: Code: 507. DB::Exception: Sharding key dummy is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fa4a 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:51.352011 [ 22866 ] {ff5047f0-5f63-44d5-be1a-fb3610b7710d} executeQuery: Code: 507. DB::Exception: Sharding key dummy is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.3.12.76.altinitystable) (from [::1]:48004) (comment: 01757_optimize_skip_unused_shards_limit.sql) (in query: -- or negative select * from dist_01757 where dummy = 0 or dummy = 1 settings optimize_skip_unused_shards_limit=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fa4a 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:51.352124 [ 22866 ] {ff5047f0-5f63-44d5-be1a-fb3610b7710d} TCPHandler: Code: 507. DB::Exception: Sharding key dummy is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fa4a 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:51.387050 [ 22866 ] {f58ca729-0a82-4c15-bb28-9631ae96130f} executeQuery: Code: 507. DB::Exception: Sharding key dummy is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.3.12.76.altinitystable) (from [::1]:48004) (comment: 01757_optimize_skip_unused_shards_limit.sql) (in query: -- and negative -- disabled for analyzer cause new implementation consider `dummy = 0 and dummy = 1` as constant False. select * from dist_01757 where dummy = 0 and dummy = 1 settings optimize_skip_unused_shards_limit=1, allow_experimental_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1039: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7db70 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f6287d 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:51.387328 [ 22866 ] {f58ca729-0a82-4c15-bb28-9631ae96130f} TCPHandler: Code: 507. DB::Exception: Sharding key dummy is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1039: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7db70 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f6287d 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:51.390424 [ 22866 ] {2ed8d257-8983-41d6-b300-d69452675192} executeQuery: Code: 507. DB::Exception: Sharding key dummy is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.3.12.76.altinitystable) (from [::1]:48004) (comment: 01757_optimize_skip_unused_shards_limit.sql) (in query: select * from dist_01757 where dummy = 0 and dummy = 2 and dummy = 3 settings optimize_skip_unused_shards_limit=1, allow_experimental_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1039: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7db70 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f6287d 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:51.390557 [ 22866 ] {2ed8d257-8983-41d6-b300-d69452675192} TCPHandler: Code: 507. DB::Exception: Sharding key dummy is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1039: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7db70 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f6287d 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:51.393100 [ 22866 ] {ea8ed4d9-a536-48cc-88f7-7ccbf215df1e} executeQuery: Code: 507. DB::Exception: Sharding key dummy is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.3.12.76.altinitystable) (from [::1]:48004) (comment: 01757_optimize_skip_unused_shards_limit.sql) (in query: select * from dist_01757 where dummy = 0 and dummy = 2 and dummy = 3 settings optimize_skip_unused_shards_limit=2, allow_experimental_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1039: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7db70 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f6287d 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:51.393236 [ 22866 ] {ea8ed4d9-a536-48cc-88f7-7ccbf215df1e} TCPHandler: Code: 507. DB::Exception: Sharding key dummy is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1039: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7db70 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f6287d 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:51.422301 [ 22866 ] {002e59ce-0845-4b91-a732-fcb798eab8ff} executeQuery: Code: 69. DB::Exception: optimize_skip_unused_shards_limit out of range (0, 9223372036854775807]. (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:48004) (comment: 01757_optimize_skip_unused_shards_limit.sql) (in query: -- ARGUMENT_OUT_OF_BOUND error select * from dist_01757 where dummy in (0, 1) settings optimize_skip_unused_shards_limit=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&&) @ 0x00000000321bd9fb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1601: DB::StorageDistributed::skipUnusedShardsWithAnalyzer(std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr) const @ 0x00000000321b1418 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1639: DB::StorageDistributed::skipUnusedShards(std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) const @ 0x00000000321ac5f2 6. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003219064c 7. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fa4a 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:51.422477 [ 22866 ] {002e59ce-0845-4b91-a732-fcb798eab8ff} TCPHandler: Code: 69. DB::Exception: optimize_skip_unused_shards_limit out of range (0, 9223372036854775807]. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&&) @ 0x00000000321bd9fb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1601: DB::StorageDistributed::skipUnusedShardsWithAnalyzer(std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr) const @ 0x00000000321b1418 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1639: DB::StorageDistributed::skipUnusedShards(std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) const @ 0x00000000321ac5f2 6. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003219064c 7. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fa4a 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:51.425389 [ 22866 ] {479ada0b-07d6-4cec-8c2c-a3a40162bf5b} executeQuery: Code: 69. DB::Exception: optimize_skip_unused_shards_limit out of range (0, 9223372036854775807]. (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:48004) (comment: 01757_optimize_skip_unused_shards_limit.sql) (in query: select * from dist_01757 where dummy in (0, 1) settings optimize_skip_unused_shards_limit=9223372036854775808;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&&) @ 0x00000000321bd9fb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1601: DB::StorageDistributed::skipUnusedShardsWithAnalyzer(std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr) const @ 0x00000000321b1418 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1639: DB::StorageDistributed::skipUnusedShards(std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) const @ 0x00000000321ac5f2 6. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003219064c 7. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fa4a 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:51.425504 [ 22866 ] {479ada0b-07d6-4cec-8c2c-a3a40162bf5b} TCPHandler: Code: 69. DB::Exception: optimize_skip_unused_shards_limit out of range (0, 9223372036854775807]. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&&) @ 0x00000000321bd9fb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1601: DB::StorageDistributed::skipUnusedShardsWithAnalyzer(std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr) const @ 0x00000000321b1418 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1639: DB::StorageDistributed::skipUnusedShards(std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) const @ 0x00000000321ac5f2 6. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003219064c 7. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fa4a 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:51.669922 [ 23639 ] {f89905dc-6eb3-4dbf-ac23-2951923058da} executeQuery: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7fdb7afff000, frame address: 0x7fdb7b3fe8b0, stack size: 4196176, maximum stack size: 8388608. (TOO_DEEP_RECURSION) (version 24.3.12.76.altinitystable) (from [::1]:47900) (comment: 01763_max_distributed_depth.sql) (in query: -- stack overflow INSERT INTO tt6 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, void*&, void const*&, unsigned long&, unsigned long&) @ 0x00000000246ed190 4. ./build_docker/./src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x00000000246ecf9c 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd84d54 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:710: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000003293ccb0 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x0000000032935ad6 11. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:179: DB::DistributedSink::writeAsync(DB::Block const&) @ 0x0000000032935159 12. ./src/Core/Block.h:25: DB::DistributedSink::consume(DB::Chunk) @ 0x0000000032932f58 13. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 19. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 20. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000003293cdc1 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x0000000032935ad6 22. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:179: DB::DistributedSink::writeAsync(DB::Block const&) @ 0x0000000032935159 23. ./src/Core/Block.h:25: DB::DistributedSink::consume(DB::Chunk) @ 0x0000000032932f58 24. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 30. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 31. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000003293cdc1 2025.03.05 21:13:51.670119 [ 23639 ] {f89905dc-6eb3-4dbf-ac23-2951923058da} TCPHandler: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7fdb7afff000, frame address: 0x7fdb7b3fe8b0, stack size: 4196176, maximum stack size: 8388608. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, void*&, void const*&, unsigned long&, unsigned long&) @ 0x00000000246ed190 4. ./build_docker/./src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x00000000246ecf9c 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd84d54 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:710: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000003293ccb0 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x0000000032935ad6 11. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:179: DB::DistributedSink::writeAsync(DB::Block const&) @ 0x0000000032935159 12. ./src/Core/Block.h:25: DB::DistributedSink::consume(DB::Chunk) @ 0x0000000032932f58 13. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 19. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 20. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000003293cdc1 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x0000000032935ad6 22. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:179: DB::DistributedSink::writeAsync(DB::Block const&) @ 0x0000000032935159 23. ./src/Core/Block.h:25: DB::DistributedSink::consume(DB::Chunk) @ 0x0000000032932f58 24. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 30. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 31. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000003293cdc1 2025.03.05 21:13:52.080200 [ 23639 ] {16c494e6-236a-48e9-9bbe-79be0d4ab771} executeQuery: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7fdb7afff000, frame address: 0x7fdb7b3fe2e0, stack size: 4197664, maximum stack size: 8388608. (TOO_DEEP_RECURSION) (version 24.3.12.76.altinitystable) (from [::1]:47900) (comment: 01763_max_distributed_depth.sql) (in query: -- stack overflow SELECT * FROM tt6;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, void*&, void const*&, unsigned long&, unsigned long&) @ 0x00000000246ed190 4. ./build_docker/./src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x00000000246ecf9c 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd84d54 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cd2a 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x00000000308a142c 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089c809 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6962: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086fd78 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./contrib/llvm-project/libcxx/include/vector:1457: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x0000000030866007 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000030865d25 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe6e4 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:0: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb47f4 16. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 17. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 21. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 22. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 23. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 26. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:76: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb48c1 27. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 28. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 2025.03.05 21:13:52.081369 [ 23639 ] {16c494e6-236a-48e9-9bbe-79be0d4ab771} TCPHandler: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7fdb7afff000, frame address: 0x7fdb7b3fe2e0, stack size: 4197664, maximum stack size: 8388608. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, void*&, void const*&, unsigned long&, unsigned long&) @ 0x00000000246ed190 4. ./build_docker/./src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x00000000246ecf9c 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd84d54 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cd2a 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x00000000308a142c 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089c809 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6962: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086fd78 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./contrib/llvm-project/libcxx/include/vector:1457: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x0000000030866007 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000030865d25 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe6e4 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:0: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb47f4 16. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 17. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 21. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 22. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 23. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 26. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:76: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb48c1 27. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 28. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 2025.03.05 21:13:52.133123 [ 22866 ] {5f4b1248-f28c-42e1-86b0-81a2be44d2ea} executeQuery: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:48172) (comment: 01762_deltasumtimestamp_datetime64.sh) (in query: SELECT deltaSumTimestamp(1, now64());), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:0: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000250da3e6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.133453 [ 22866 ] {5f4b1248-f28c-42e1-86b0-81a2be44d2ea} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001908baea 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:0: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000250da3e6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.225378 [ 48606 ] {4d010fb6-b198-4c79-9d60-86e23c11a795} executeQuery: Code: 507. DB::Exception: Sharding key intHash64(dummy) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.3.12.76.altinitystable) (from [::1]:48010) (comment: 01756_optimize_skip_unused_shards_rewrite_in.sql) (in query: -- optimize_skip_unused_shards does not support non-constants select * from dist_01756 where dummy in (select * from system.one);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fa4a 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.225528 [ 48606 ] {4d010fb6-b198-4c79-9d60-86e23c11a795} TCPHandler: Code: 507. DB::Exception: Sharding key intHash64(dummy) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fa4a 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.228154 [ 48606 ] {c53460b6-b9a4-472e-a65f-6176595f16a8} executeQuery: Code: 507. DB::Exception: Sharding key intHash64(dummy) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.3.12.76.altinitystable) (from [::1]:48010) (comment: 01756_optimize_skip_unused_shards_rewrite_in.sql) (in query: -- this is a constant for analyzer select * from dist_01756 where dummy in (toUInt8(0)) settings allow_experimental_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1039: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7db70 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f6287d 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.228314 [ 48606 ] {c53460b6-b9a4-472e-a65f-6176595f16a8} TCPHandler: Code: 507. DB::Exception: Sharding key intHash64(dummy) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1039: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7db70 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f6287d 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.230759 [ 48606 ] {3a480505-70fc-4144-ae71-ebc47acdf330} executeQuery: Code: 507. DB::Exception: Sharding key intHash64(dummy) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.3.12.76.altinitystable) (from [::1]:48010) (comment: 01756_optimize_skip_unused_shards_rewrite_in.sql) (in query: -- NOT IN does not supported select * from dist_01756 where dummy not in (0, 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fa4a 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.230875 [ 48606 ] {3a480505-70fc-4144-ae71-ebc47acdf330} TCPHandler: Code: 507. DB::Exception: Sharding key intHash64(dummy) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fa4a 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.369799 [ 48606 ] {4d371e96-cd84-4030-b846-48341ab0ca4a} executeQuery: Code: 507. DB::Exception: Sharding key cityHash64(key) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.3.12.76.altinitystable) (from [::1]:48010) (comment: 01756_optimize_skip_unused_shards_rewrite_in.sql) (in query: -- analyzer does support this select * from dist_01756_str where key in ('0', Null) settings allow_experimental_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1039: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7db70 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f6287d 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.369945 [ 48606 ] {4d371e96-cd84-4030-b846-48341ab0ca4a} TCPHandler: Code: 507. DB::Exception: Sharding key cityHash64(key) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1039: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000030f7db70 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000030f6287d 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030f560d0 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030f4d373 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000310c21ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:153: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000310bf65a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000310c874c 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x00000000310c6128 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.416444 [ 48606 ] {4ab2ecce-8fa0-42f6-9ae0-4f0149a26b29} executeQuery: Code: 53. DB::Exception: Cannot convert string 255foo to type UInt8. (TYPE_MISMATCH) (version 24.3.12.76.altinitystable) (from [::1]:48010) (comment: 01756_optimize_skip_unused_shards_rewrite_in.sql) (in query: select * from dist_01756_column where dummy in (0, '255foo');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169a592 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 6. ./src/Core/Field.h:450: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&) @ 0x000000003169aece 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000030944ddf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103c1c6 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 10. ./build_docker/./src/Planner/CollectSets.cpp:121: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003103b763 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008ed2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000003100323f 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc67c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.416715 [ 48606 ] {4ab2ecce-8fa0-42f6-9ae0-4f0149a26b29} TCPHandler: Code: 53. DB::Exception: Cannot convert string 255foo to type UInt8. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169a592 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 6. ./src/Core/Field.h:450: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&) @ 0x000000003169aece 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000030944ddf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103c1c6 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 10. ./build_docker/./src/Planner/CollectSets.cpp:121: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003103b763 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008ed2 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000003100323f 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc67c 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.429758 [ 48606 ] {29330350-2b1a-46c9-8e1b-7fb8bc07523f} executeQuery: Code: 507. DB::Exception: Sharding key intHash64(dummy) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.3.12.76.altinitystable) (from [::1]:48010) (comment: 01756_optimize_skip_unused_shards_rewrite_in.sql) (in query: select * from dist_01756 where dummy in (0, 2) settings optimize_skip_unused_shards_limit=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fa4a 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.429868 [ 48606 ] {29330350-2b1a-46c9-8e1b-7fb8bc07523f} TCPHandler: Code: 507. DB::Exception: Sharding key intHash64(dummy) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fa4a 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.923218 [ 22866 ] {56c48c9a-725c-4a02-812a-e9806f9e51a0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:48324) (comment: 01752_distributed_query_sigsegv.sql) (in query: -- this is enough to trigger the regression SELECT throwIf(dummy = 0) FROM remote('127.1', system.one);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.923309 [ 22866 ] {56c48c9a-725c-4a02-812a-e9806f9e51a0} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.944332 [ 22866 ] {cee341f3-31a9-47f0-80a3-4e0f124b2ed2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:48324) (comment: 01752_distributed_query_sigsegv.sql) (in query: -- these are just in case SELECT throwIf(dummy = 0) FROM remote('127.{1,2}', system.one);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 17. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 18. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.944365 [ 22860 ] {bfd5af8d-246d-47a4-af6d-bb8f0752e591} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:47302) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.944503 [ 22860 ] {bfd5af8d-246d-47a4-af6d-bb8f0752e591} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.944587 [ 22866 ] {cee341f3-31a9-47f0-80a3-4e0f124b2ed2} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 17. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 18. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.944820 [ 22860 ] {bfd5af8d-246d-47a4-af6d-bb8f0752e591} TCPHandler: Client has gone away. 2025.03.05 21:13:52.952485 [ 48599 ] {65e09cf4-bd31-4ae8-82a1-978df5b0240d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:47304) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.952663 [ 48599 ] {65e09cf4-bd31-4ae8-82a1-978df5b0240d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.953641 [ 22860 ] {d44bfeb0-9cd0-4a12-b1d7-cd71c8862be4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:46126) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.953781 [ 22860 ] {d44bfeb0-9cd0-4a12-b1d7-cd71c8862be4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.954399 [ 22866 ] {ac3f2ba9-4707-408b-ad08-8275c76fbe7b} executeQuery: Code: 395. DB::Exception: Received from 127.2:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:48324) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(dummy = 0) FROM remote('127.{1,2}', system.one) SETTINGS prefer_localhost_replica=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:52.954591 [ 22866 ] {ac3f2ba9-4707-408b-ad08-8275c76fbe7b} TCPHandler: Code: 395. DB::Exception: Received from 127.2:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:52.961739 [ 22860 ] {397cf17d-0262-48f5-aff0-2cb6b119954d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:47318) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.961837 [ 22860 ] {397cf17d-0262-48f5-aff0-2cb6b119954d} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.962575 [ 48599 ] {20d118cd-97ea-4e22-92d0-38b1c939ed45} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:46140) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.962678 [ 48599 ] {20d118cd-97ea-4e22-92d0-38b1c939ed45} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.963342 [ 22866 ] {159ef02c-063a-4b68-b7ad-b80211856291} executeQuery: Code: 395. DB::Exception: Received from 127.2:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:48324) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(dummy = 0) FROM remote('127.{1,2}', system.one) SETTINGS prefer_localhost_replica=0, distributed_group_by_no_merge=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:52.963646 [ 22866 ] {159ef02c-063a-4b68-b7ad-b80211856291} TCPHandler: Code: 395. DB::Exception: Received from 127.2:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:52.972052 [ 48599 ] {dcc0b7a9-1e02-40cf-8a52-54534d982ff7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:47324) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.972116 [ 22860 ] {3abbc840-9982-4f08-837d-cc28775311d1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:46148) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.972139 [ 48599 ] {dcc0b7a9-1e02-40cf-8a52-54534d982ff7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.972265 [ 22860 ] {3abbc840-9982-4f08-837d-cc28775311d1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:52.973149 [ 22866 ] {2078b43f-2dd4-4e3a-a3bd-cc7d4e328410} executeQuery: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:48324) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(dummy = 0) FROM remote('127.{1,2}', system.one) SETTINGS prefer_localhost_replica=0, distributed_group_by_no_merge=2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:52.973436 [ 22866 ] {2078b43f-2dd4-4e3a-a3bd-cc7d4e328410} TCPHandler: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:53.811922 [ 48599 ] {2c5461b8-3a36-46ac-b3fb-2ddb3ac8ced8} executeQuery: Code: 48. DB::Exception: Table engine View doesn't support mutations. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:48486) (comment: 01745_alter_delete_view.sql) (in query: ALTER TABLE test_view DELETE WHERE pk = 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/IStorage.cpp:0: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x00000000320df9ae 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795541 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:53.812131 [ 48599 ] {2c5461b8-3a36-46ac-b3fb-2ddb3ac8ced8} TCPHandler: Code: 48. DB::Exception: Table engine View doesn't support mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/IStorage.cpp:0: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x00000000320df9ae 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795541 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:54.493320 [ 23620 ] {1221d039-aeb1-460a-9c4d-e0682c4f18fd} executeQuery: Code: 407. DB::Exception: DateTime64 convert overflow. Float is out of Decimal range: In scope SELECT toDateTime64(9300000000., 9, 'UTC'). (DECIMAL_OVERFLOW) (version 24.3.12.76.altinitystable) (from [::1]:48638) (comment: 01734_datetime64_from_float.sql) (in query: SELECT toDateTime64(9300000000.0, 9, 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:0: void DB::convertToDecimalImpl, DB::DataTypeDateTime64, void>(DB::DataTypeNumber::FieldType const&, unsigned int, DB::DataTypeDateTime64::FieldType&) @ 0x000000002f521d60 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: DB::DataTypeDateTime64::FieldType DB::convertToDecimal, DB::DataTypeDateTime64>(DB::DataTypeNumber::FieldType const&, unsigned int) @ 0x000000002f524f39 6. void DB::Transformer, DB::DataTypeDateTime64, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000184bdcf5 7. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime64, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0> const&) @ 0x00000000184bd5f1 8. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000186707c7 9. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 14. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:13:54.493598 [ 23620 ] {1221d039-aeb1-460a-9c4d-e0682c4f18fd} TCPHandler: Code: 407. DB::Exception: DateTime64 convert overflow. Float is out of Decimal range: In scope SELECT toDateTime64(9300000000., 9, 'UTC'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:0: void DB::convertToDecimalImpl, DB::DataTypeDateTime64, void>(DB::DataTypeNumber::FieldType const&, unsigned int, DB::DataTypeDateTime64::FieldType&) @ 0x000000002f521d60 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: DB::DataTypeDateTime64::FieldType DB::convertToDecimal, DB::DataTypeDateTime64>(DB::DataTypeNumber::FieldType const&, unsigned int) @ 0x000000002f524f39 6. void DB::Transformer, DB::DataTypeDateTime64, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0> const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000184bdcf5 7. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime64, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTime64TransformFloat, double, (DB::FormatSettings::DateTimeOverflowBehavior)0> const&) @ 0x00000000184bd5f1 8. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000186707c7 9. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 14. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:13:54.530690 [ 23620 ] {4c0d9ab1-24a7-4e86-ab9c-aed8c2a4e69d} executeQuery: Code: 407. DB::Exception: Decimal math overflow: In scope SELECT toDateTime64(9300000000, 9, 'UTC'). (DECIMAL_OVERFLOW) (version 24.3.12.76.altinitystable) (from [::1]:48638) (comment: 01734_datetime64_from_float.sql) (in query: SELECT toDateTime64(9300000000, 9, 'UTC');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::DecimalUtils::multiplyAdd(long const&, long const&, long const&, long&) @ 0x0000000018218a56 5. void DB::Transformer, DB::DataTypeDateTime64, DB::(anonymous namespace)::ToDateTime64TransformUnsigned, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTime64TransformUnsigned const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000184b959c 6. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime64, DB::(anonymous namespace)::ToDateTime64TransformUnsigned, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTime64TransformUnsigned const&) @ 0x00000000184b8e71 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018677611 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:13:54.530979 [ 23620 ] {4c0d9ab1-24a7-4e86-ab9c-aed8c2a4e69d} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: In scope SELECT toDateTime64(9300000000, 9, 'UTC'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::DecimalUtils::multiplyAdd(long const&, long const&, long const&, long&) @ 0x0000000018218a56 5. void DB::Transformer, DB::DataTypeDateTime64, DB::(anonymous namespace)::ToDateTime64TransformUnsigned, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTime64TransformUnsigned const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000184b959c 6. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime64, DB::(anonymous namespace)::ToDateTime64TransformUnsigned, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTime64TransformUnsigned const&) @ 0x00000000184b8e71 7. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018677611 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:13:54.826031 [ 48599 ] {741b1655-ae29-44b4-ae60-1bbd07bbeb6f} executeQuery: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types: While processing _CAST(a, 'Array(String)') AS a. (TYPE_MISMATCH) (version 24.3.12.76.altinitystable) (from [::1]:48734) (comment: 01732_alters_bad_conversions.sql) (in query: ALTER TABLE bad_conversions MODIFY COLUMN a Array(String);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000001825a617 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e5b2 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002fb5db0b 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:244: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002fb5d0e3 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:645: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe2f05d 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe439bf 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe33cd5 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002fe1eecd 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, std::shared_ptr&, bool) @ 0x000000002fddf8d7 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002fdf74a8 15. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:167: DB::(anonymous namespace)::createExpressions(DB::Block const&, std::shared_ptr, bool, std::shared_ptr) @ 0x000000003172ac03 16. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:181: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000003172a35c 17. ./src/Core/Block.h:25: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40dab 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 19. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:54.864676 [ 48599 ] {741b1655-ae29-44b4-ae60-1bbd07bbeb6f} TCPHandler: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types: While processing _CAST(a, 'Array(String)') AS a. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000001825a617 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e5b2 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002fb5db0b 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:244: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002fb5d0e3 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:645: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe2f05d 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe439bf 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe33cd5 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002fe1eecd 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, std::shared_ptr&, bool) @ 0x000000002fddf8d7 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002fdf74a8 15. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:167: DB::(anonymous namespace)::createExpressions(DB::Block const&, std::shared_ptr, bool, std::shared_ptr) @ 0x000000003172ac03 16. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:181: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000003172a35c 17. ./src/Core/Block.h:25: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40dab 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 19. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:54.864683 [ 48611 ] {bd57bd95-e176-43f4-8026-b11291dbab36} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(__table1.f : 0, 1048575_UInt32 :: 1) -> plus(__table1.f, 1048575_UInt32) Decimal(38, 38) : 5'. (DECIMAL_OVERFLOW) (version 24.3.12.76.altinitystable) (from [::1]:48746) (comment: 01732_bigint_ubsan.sql) (in query: SELECT f + 1048575, f - 21, f - 84, f * 21, f * -21, f / 21, f / 84 FROM decimal WHERE f > 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, true>::applyScaled(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x00000000208be1f3 5. void DB::impl_::DecimalBinaryOperation>, true>::process<(DB::impl_::OpCase)2, true, false, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, wide::integer<128ul, int>>(DB::PODArray>, 4096ul, Allocator, 63ul, 64ul> const&, wide::integer<128ul, int> const&, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>&, wide::integer<128ul, int>, wide::integer<128ul, int>, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000209cf4a6 6. void DB::FunctionBinaryArithmetic::helperInvokeEither<(DB::impl_::OpCase)2, true, false, DB::impl_::DecimalBinaryOperation>, false>, DB::impl_::DecimalBinaryOperation>, true>, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, wide::integer<128ul, int>, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, DB::Decimal>, DB::Decimal>>(DB::PODArray>, 4096ul, Allocator, 63ul, 64ul> const&, wide::integer<128ul, int> const&, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>&, DB::Decimal>, DB::Decimal>, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000020ba41f5 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::ColumnDecimal>>, DB::ColumnVector>(DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal>> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000020ba6e20 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000020ba6300 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeNumber>(auto const&, auto const&) const @ 0x0000000020ba6002 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000020ba161f 11. auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const @ 0x0000000020a44df2 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000020a4485f 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000020a3f98c 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a3b2b4 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a38f11 16. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 19. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 23. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 28. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 29. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 30. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 2025.03.05 21:13:54.865022 [ 48611 ] {bd57bd95-e176-43f4-8026-b11291dbab36} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(__table1.f : 0, 1048575_UInt32 :: 1) -> plus(__table1.f, 1048575_UInt32) Decimal(38, 38) : 5'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, true>::applyScaled(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x00000000208be1f3 5. void DB::impl_::DecimalBinaryOperation>, true>::process<(DB::impl_::OpCase)2, true, false, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, wide::integer<128ul, int>>(DB::PODArray>, 4096ul, Allocator, 63ul, 64ul> const&, wide::integer<128ul, int> const&, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>&, wide::integer<128ul, int>, wide::integer<128ul, int>, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000209cf4a6 6. void DB::FunctionBinaryArithmetic::helperInvokeEither<(DB::impl_::OpCase)2, true, false, DB::impl_::DecimalBinaryOperation>, false>, DB::impl_::DecimalBinaryOperation>, true>, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, wide::integer<128ul, int>, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, DB::Decimal>, DB::Decimal>>(DB::PODArray>, 4096ul, Allocator, 63ul, 64ul> const&, wide::integer<128ul, int> const&, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>&, DB::Decimal>, DB::Decimal>, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000020ba41f5 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::ColumnDecimal>>, DB::ColumnVector>(DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal>> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000020ba6e20 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000020ba6300 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeNumber>(auto const&, auto const&) const @ 0x0000000020ba6002 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000020ba161f 11. auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const @ 0x0000000020a44df2 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000020a4485f 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000020a3f98c 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a3b2b4 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a38f11 16. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 19. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 23. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 28. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 29. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 30. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 2025.03.05 21:13:54.915303 [ 48611 ] {694b6317-5873-4f0c-975d-7da7691b0515} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(__table1.f : 0, -2_Int8 :: 1) -> plus(__table1.f, -2_Int8) Decimal(38, 38) : 6'. (DECIMAL_OVERFLOW) (version 24.3.12.76.altinitystable) (from [::1]:48746) (comment: 01732_bigint_ubsan.sql) (in query: SELECT f + -2, f - 21, f - 84, f * 21, f * -21, f / 9223372036854775807, f / 84 FROM decimal WHERE f > 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, true>::applyScaled(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x00000000208be1f3 5. void DB::impl_::DecimalBinaryOperation>, true>::process<(DB::impl_::OpCase)2, true, false, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, wide::integer<128ul, int>>(DB::PODArray>, 4096ul, Allocator, 63ul, 64ul> const&, wide::integer<128ul, int> const&, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>&, wide::integer<128ul, int>, wide::integer<128ul, int>, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000209cf4a6 6. void DB::FunctionBinaryArithmetic::helperInvokeEither<(DB::impl_::OpCase)2, true, false, DB::impl_::DecimalBinaryOperation>, false>, DB::impl_::DecimalBinaryOperation>, true>, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, wide::integer<128ul, int>, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, DB::Decimal>, DB::Decimal>>(DB::PODArray>, 4096ul, Allocator, 63ul, 64ul> const&, wide::integer<128ul, int> const&, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>&, DB::Decimal>, DB::Decimal>, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000020ba41f5 7. _ZNK2DB24FunctionBinaryArithmeticINS_8PlusImplENS_8NamePlusELb1ELb1ELb0EE25executeNumericWithDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIDB8_EESB_SB_SE_NS_13ColumnDecimalISA_EENS_12ColumnVectorISD_EEEEN3COWINS_7IColumnEE13immutable_ptrISK_EERKT2_RKT3_PKNS_11ColumnConstESW_PKT4_PKT5_mPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEE @ 0x0000000020bae361 8. COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric>>, DB::DataTypeNumber<_BitInt(8)>>(std::vector> const&, DB::DataTypeDecimal>> const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000020bad540 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeNumber<_BitInt(8)>>(auto const&, auto const&) const @ 0x0000000020bad242 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000020ba181f 11. auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const @ 0x0000000020a44df2 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000020a4485f 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000020a3f98c 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a3b2b4 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a38f11 16. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 19. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 23. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 28. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 29. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 30. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 2025.03.05 21:13:54.947025 [ 48599 ] {76c4ff1b-14b9-4a04-a699-8699e35958a7} executeQuery: Code: 70. DB::Exception: Enum conversion changes value for element 'foo' from 1 to 2: While processing _CAST(e, 'Enum8(\'bar\' = 1, \'foo\' = 2)') AS e. (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:48734) (comment: 01732_alters_bad_conversions.sql) (in query: ALTER TABLE bad_conversions_2 MODIFY COLUMN e Enum('bar' = 1, 'foo' = 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x00000000187c28c3 4. bool DB::callOnIndexAndDataType const&, std::shared_ptr const&, bool) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda'(auto const&)&) @ 0x0000000018261142 5. DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x00000000182569fe 6. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e5b2 7. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002fb5db0b 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:244: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002fb5d0e3 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:645: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe2f05d 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe439bf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe33cd5 13. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002fe1eecd 14. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, std::shared_ptr&, bool) @ 0x000000002fddf8d7 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002fdf74a8 16. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:167: DB::(anonymous namespace)::createExpressions(DB::Block const&, std::shared_ptr, bool, std::shared_ptr) @ 0x000000003172ac03 17. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:181: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000003172a35c 18. ./src/Core/Block.h:25: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40dab 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 20. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:54.971567 [ 10241 ] {d0f53228-355b-4909-821d-f7594734653c} executeQuery: Code: 1. DB::Exception: Constraint `c0` does not return a value of type UInt8. (UNSUPPORTED_METHOD) (version 24.3.12.76.altinitystable) (from [::1]:48842) (comment: 01721_constraints_constant_expressions.sql) (in query: INSERT INTO constraint_constant_number_expression_non_uint8 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ef84 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:54.971644 [ 48611 ] {694b6317-5873-4f0c-975d-7da7691b0515} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(__table1.f : 0, -2_Int8 :: 1) -> plus(__table1.f, -2_Int8) Decimal(38, 38) : 6'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, true>::applyScaled(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x00000000208be1f3 5. void DB::impl_::DecimalBinaryOperation>, true>::process<(DB::impl_::OpCase)2, true, false, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, wide::integer<128ul, int>>(DB::PODArray>, 4096ul, Allocator, 63ul, 64ul> const&, wide::integer<128ul, int> const&, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>&, wide::integer<128ul, int>, wide::integer<128ul, int>, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000209cf4a6 6. void DB::FunctionBinaryArithmetic::helperInvokeEither<(DB::impl_::OpCase)2, true, false, DB::impl_::DecimalBinaryOperation>, false>, DB::impl_::DecimalBinaryOperation>, true>, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, wide::integer<128ul, int>, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, DB::Decimal>, DB::Decimal>>(DB::PODArray>, 4096ul, Allocator, 63ul, 64ul> const&, wide::integer<128ul, int> const&, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>&, DB::Decimal>, DB::Decimal>, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000020ba41f5 7. _ZNK2DB24FunctionBinaryArithmeticINS_8PlusImplENS_8NamePlusELb1ELb1ELb0EE25executeNumericWithDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIDB8_EESB_SB_SE_NS_13ColumnDecimalISA_EENS_12ColumnVectorISD_EEEEN3COWINS_7IColumnEE13immutable_ptrISK_EERKT2_RKT3_PKNS_11ColumnConstESW_PKT4_PKT5_mPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEE @ 0x0000000020bae361 8. COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric>>, DB::DataTypeNumber<_BitInt(8)>>(std::vector> const&, DB::DataTypeDecimal>> const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000020bad540 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeNumber<_BitInt(8)>>(auto const&, auto const&) const @ 0x0000000020bad242 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000020ba181f 11. auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const @ 0x0000000020a44df2 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000020a4485f 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000020a3f98c 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a3b2b4 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a38f11 16. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 19. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 23. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 28. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 29. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 30. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 2025.03.05 21:13:54.971669 [ 48599 ] {76c4ff1b-14b9-4a04-a699-8699e35958a7} TCPHandler: Code: 70. DB::Exception: Enum conversion changes value for element 'foo' from 1 to 2: While processing _CAST(e, 'Enum8(\'bar\' = 1, \'foo\' = 2)') AS e. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x00000000187c28c3 4. bool DB::callOnIndexAndDataType const&, std::shared_ptr const&, bool) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda'(auto const&)&) @ 0x0000000018261142 5. DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x00000000182569fe 6. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e5b2 7. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002fb5db0b 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:244: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002fb5d0e3 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:645: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe2f05d 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe439bf 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe33cd5 13. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002fe1eecd 14. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, std::shared_ptr&, bool) @ 0x000000002fddf8d7 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002fdf74a8 16. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:167: DB::(anonymous namespace)::createExpressions(DB::Block const&, std::shared_ptr, bool, std::shared_ptr) @ 0x000000003172ac03 17. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:181: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000003172a35c 18. ./src/Core/Block.h:25: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b40dab 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 20. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:54.971714 [ 10241 ] {d0f53228-355b-4909-821d-f7594734653c} TCPHandler: Code: 1. DB::Exception: Constraint `c0` does not return a value of type UInt8. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ef84 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:54.971715 [ 48626 ] {837fd7b8-6111-4cf6-8d2a-bdd40315c85d} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:50614). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50614) (comment: 01730_distributed_group_by_no_merge_order_by_long.sql) (in query: SELECT `__table1`.`number` AS `number` FROM view(SELECT * FROM numbers(1000000.)) AS `__table1` GROUP BY `__table1`.`number` ORDER BY `__table1`.`number` ASC LIMIT _CAST(20, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:54.992315 [ 730 ] {752df7d0-2fad-43e7-b459-5169796ac0d5} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 100.66 MiB (attempt to allocate chunk of 1048768 bytes), maximum: 100.00 MiB.: while receiving packet from 127.8:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:48754) (comment: 01730_distributed_group_by_no_merge_order_by_long.sql) (in query: -- does not use 127.1 due to prefer_localhost_replica select * from remote('127.{2..11}', view(select * from numbers(1e6))) group by number order by number limit 20 settings distributed_group_by_no_merge=0, max_memory_usage='100Mi';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x00000000180629f4 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000018062951 10. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:0: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f64ee76 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:142: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5a438d 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::NativeReader::readData(DB::ISerialization const&, COW::immutable_ptr&, DB::ReadBuffer&, unsigned long, double) @ 0x0000000033505f67 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::NativeReader::read() @ 0x00000000335073b8 14. ./build_docker/./src/Client/Connection.cpp:1161: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003328dd7a 15. ./build_docker/./src/Client/Connection.cpp:1140: DB::Connection::receiveData() @ 0x000000003328cc94 16. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328bb4c 17. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 20. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 21. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:54.992344 [ 48626 ] {837fd7b8-6111-4cf6-8d2a-bdd40315c85d} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:50614). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:54.992587 [ 48626 ] {837fd7b8-6111-4cf6-8d2a-bdd40315c85d} TCPHandler: Client has gone away. 2025.03.05 21:13:54.993525 [ 48614 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:40098). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:54.993909 [ 14920 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:50292). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:54.994263 [ 48581 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:38352). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:54.994503 [ 730 ] {752df7d0-2fad-43e7-b459-5169796ac0d5} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 100.66 MiB (attempt to allocate chunk of 1048768 bytes), maximum: 100.00 MiB.: while receiving packet from 127.8:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x00000000180629f4 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000018062951 10. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:0: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f64ee76 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:142: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5a438d 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::NativeReader::readData(DB::ISerialization const&, COW::immutable_ptr&, DB::ReadBuffer&, unsigned long, double) @ 0x0000000033505f67 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::NativeReader::read() @ 0x00000000335073b8 14. ./build_docker/./src/Client/Connection.cpp:1161: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003328dd7a 15. ./build_docker/./src/Client/Connection.cpp:1140: DB::Connection::receiveData() @ 0x000000003328cc94 16. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328bb4c 17. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 20. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 21. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:55.026328 [ 10241 ] {b9629baf-343e-4ce8-8633-b4914a033953} executeQuery: Code: 469. DB::Exception: Constraint `c0` for table test_2i5z5ti2.constraint_constant_nullable_expression_that_contains_null (749b21ae-008f-43e2-836b-b102343d4285) is violated. Expression: (nullIf(1 % 2, 1)).Constraint expression returns nullable column that contains null value. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:48842) (comment: 01721_constraints_constant_expressions.sql) (in query: INSERT INTO constraint_constant_nullable_expression_that_contains_null VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1f207 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.026497 [ 10241 ] {b9629baf-343e-4ce8-8633-b4914a033953} TCPHandler: Code: 469. DB::Exception: Constraint `c0` for table test_2i5z5ti2.constraint_constant_nullable_expression_that_contains_null (749b21ae-008f-43e2-836b-b102343d4285) is violated. Expression: (nullIf(1 % 2, 1)).Constraint expression returns nullable column that contains null value. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1f207 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.215036 [ 12525 ] {e2e3e75e-06c7-4f34-8a25-c4595e03a971} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 40.84 MiB (attempt to allocate chunk of 33555032 bytes), maximum: 20.00 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50306) (comment: 01730_distributed_group_by_no_merge_order_by_long.sql) (in query: SELECT `__table1`.`number` AS `number` FROM view(SELECT * FROM numbers(1000000.)) AS `__table1` GROUP BY `__table1`.`number` ORDER BY `__table1`.`number` ASC LIMIT _CAST(1000000, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:114: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461f421 8. ./src/Common/HashTable/HashTable.h:522: auto DB::constructWithReserveIfPossible, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(unsigned long) @ 0x000000003034a573 9. ./build_docker/./src/Interpreters/AggregatedDataVariants.cpp:98: DB::AggregatedDataVariants::init(DB::AggregatedDataVariants::Type, std::optional) @ 0x000000003034519d 10. ./build_docker/./src/Interpreters/Aggregator.cpp:249: (anonymous namespace)::initDataVariantsWithSizeHint(DB::AggregatedDataVariants&, DB::AggregatedDataVariants::Type, DB::Aggregator::Params const&) @ 0x000000002fe5a1b2 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1551: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe62fdc 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 17. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 18. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.215088 [ 48614 ] {4bbf174f-7dc0-4838-a207-f0c6dc45f229} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 40.84 MiB (attempt to allocate chunk of 33555032 bytes), maximum: 20.00 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:47348) (comment: 01730_distributed_group_by_no_merge_order_by_long.sql) (in query: SELECT `__table1`.`number` AS `number` FROM view(SELECT * FROM numbers(1000000.)) AS `__table1` GROUP BY `__table1`.`number` ORDER BY `__table1`.`number` ASC LIMIT _CAST(1000000, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:114: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461f421 8. ./src/Common/HashTable/HashTable.h:522: auto DB::constructWithReserveIfPossible, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(unsigned long) @ 0x000000003034a573 9. ./build_docker/./src/Interpreters/AggregatedDataVariants.cpp:98: DB::AggregatedDataVariants::init(DB::AggregatedDataVariants::Type, std::optional) @ 0x000000003034519d 10. ./build_docker/./src/Interpreters/Aggregator.cpp:249: (anonymous namespace)::initDataVariantsWithSizeHint(DB::AggregatedDataVariants&, DB::AggregatedDataVariants::Type, DB::Aggregator::Params const&) @ 0x000000002fe5a1b2 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1551: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe62fdc 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 17. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 18. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.215148 [ 23590 ] {18bbebda-497e-48d3-8269-6fa03c313a06} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 40.84 MiB (attempt to allocate chunk of 33555032 bytes), maximum: 20.00 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:48778) (comment: 01730_distributed_group_by_no_merge_order_by_long.sql) (in query: SELECT `__table1`.`number` AS `number` FROM view(SELECT * FROM numbers(1000000.)) AS `__table1` GROUP BY `__table1`.`number` ORDER BY `__table1`.`number` ASC LIMIT _CAST(1000000, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:114: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461f421 8. ./src/Common/HashTable/HashTable.h:522: auto DB::constructWithReserveIfPossible, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(unsigned long) @ 0x000000003034a573 9. ./build_docker/./src/Interpreters/AggregatedDataVariants.cpp:98: DB::AggregatedDataVariants::init(DB::AggregatedDataVariants::Type, std::optional) @ 0x000000003034519d 10. ./build_docker/./src/Interpreters/Aggregator.cpp:249: (anonymous namespace)::initDataVariantsWithSizeHint(DB::AggregatedDataVariants&, DB::AggregatedDataVariants::Type, DB::Aggregator::Params const&) @ 0x000000002fe5a1b2 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1551: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe62fdc 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 17. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 18. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.228840 [ 730 ] {39dbefe5-8e95-4c56-a03f-5d88d45abe33} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 20.65 MiB (attempt to allocate chunk of 1048967 bytes), maximum: 20.00 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:48754) (comment: 01730_distributed_group_by_no_merge_order_by_long.sql) (in query: -- since the MergingSortedTransform will start processing only when all ports (remotes) will have some data, -- and the query with GROUP BY on remote servers will first do GROUP BY and then send the block, -- so the initiator will first receive all blocks from remotes and only after start merging, -- and will hit the memory limit. select * from remote('127.{2..11}', view(select * from numbers(1e6))) group by number order by number limit 1e6 settings distributed_group_by_no_merge=2, max_memory_usage='20Mi', max_block_size=4294967296;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x0000000024701dfb 9. ./src/IO/BufferWithOwnMemory.h:0: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x000000002473a644 10. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:187: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x00000000248833af 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, Poco::Net::StreamSocket&) @ 0x000000002f8f03c1 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], Poco::Net::StreamSocket&, void>(std::allocator const&, Poco::Net::StreamSocket&) @ 0x000000002f8f015e 13. ./build_docker/./src/Client/Connection.cpp:195: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x0000000033274215 14. ./build_docker/./src/Client/ConnectionEstablisher.cpp:49: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&) @ 0x0000000033296b35 15. ./build_docker/./src/Client/ConnectionEstablisher.cpp:0: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x0000000033299b58 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:55.228892 [ 23587 ] {2bb48299-bc4d-4263-ba9c-12405674fe2d} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 40.84 MiB (attempt to allocate chunk of 33555032 bytes), maximum: 20.00 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50632) (comment: 01730_distributed_group_by_no_merge_order_by_long.sql) (in query: SELECT `__table1`.`number` AS `number` FROM view(SELECT * FROM numbers(1000000.)) AS `__table1` GROUP BY `__table1`.`number` ORDER BY `__table1`.`number` ASC LIMIT _CAST(1000000, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:114: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461f421 8. ./src/Common/HashTable/HashTable.h:522: auto DB::constructWithReserveIfPossible, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(unsigned long) @ 0x000000003034a573 9. ./build_docker/./src/Interpreters/AggregatedDataVariants.cpp:98: DB::AggregatedDataVariants::init(DB::AggregatedDataVariants::Type, std::optional) @ 0x000000003034519d 10. ./build_docker/./src/Interpreters/Aggregator.cpp:249: (anonymous namespace)::initDataVariantsWithSizeHint(DB::AggregatedDataVariants&, DB::AggregatedDataVariants::Type, DB::Aggregator::Params const&) @ 0x000000002fe5a1b2 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1551: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe62fdc 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 17. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 18. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.246149 [ 23597 ] {b896cbb8-1dd5-4673-8391-1c9911a86a72} executeQuery: Code: 469. DB::Exception: Constraint `c0` for table test_uhi6u1dy.constraint_on_nullable_type (9221ebaa-3fa4-41af-8612-e0a339921323) is violated at row 1. Expression: (id = 1). Column values: id = 0. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:48864) (comment: 01720_constraints_complex_types.sql) (in query: INSERT INTO constraint_on_nullable_type VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.246263 [ 12525 ] {e2e3e75e-06c7-4f34-8a25-c4595e03a971} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 40.84 MiB (attempt to allocate chunk of 33555032 bytes), maximum: 20.00 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:114: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461f421 8. ./src/Common/HashTable/HashTable.h:522: auto DB::constructWithReserveIfPossible, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(unsigned long) @ 0x000000003034a573 9. ./build_docker/./src/Interpreters/AggregatedDataVariants.cpp:98: DB::AggregatedDataVariants::init(DB::AggregatedDataVariants::Type, std::optional) @ 0x000000003034519d 10. ./build_docker/./src/Interpreters/Aggregator.cpp:249: (anonymous namespace)::initDataVariantsWithSizeHint(DB::AggregatedDataVariants&, DB::AggregatedDataVariants::Type, DB::Aggregator::Params const&) @ 0x000000002fe5a1b2 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1551: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe62fdc 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 17. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 18. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.246333 [ 48614 ] {4bbf174f-7dc0-4838-a207-f0c6dc45f229} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 40.84 MiB (attempt to allocate chunk of 33555032 bytes), maximum: 20.00 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:114: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461f421 8. ./src/Common/HashTable/HashTable.h:522: auto DB::constructWithReserveIfPossible, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(unsigned long) @ 0x000000003034a573 9. ./build_docker/./src/Interpreters/AggregatedDataVariants.cpp:98: DB::AggregatedDataVariants::init(DB::AggregatedDataVariants::Type, std::optional) @ 0x000000003034519d 10. ./build_docker/./src/Interpreters/Aggregator.cpp:249: (anonymous namespace)::initDataVariantsWithSizeHint(DB::AggregatedDataVariants&, DB::AggregatedDataVariants::Type, DB::Aggregator::Params const&) @ 0x000000002fe5a1b2 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1551: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe62fdc 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 17. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 18. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.246481 [ 23590 ] {18bbebda-497e-48d3-8269-6fa03c313a06} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 40.84 MiB (attempt to allocate chunk of 33555032 bytes), maximum: 20.00 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:114: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461f421 8. ./src/Common/HashTable/HashTable.h:522: auto DB::constructWithReserveIfPossible, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(unsigned long) @ 0x000000003034a573 9. ./build_docker/./src/Interpreters/AggregatedDataVariants.cpp:98: DB::AggregatedDataVariants::init(DB::AggregatedDataVariants::Type, std::optional) @ 0x000000003034519d 10. ./build_docker/./src/Interpreters/Aggregator.cpp:249: (anonymous namespace)::initDataVariantsWithSizeHint(DB::AggregatedDataVariants&, DB::AggregatedDataVariants::Type, DB::Aggregator::Params const&) @ 0x000000002fe5a1b2 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1551: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe62fdc 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 17. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 18. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.246606 [ 23587 ] {2bb48299-bc4d-4263-ba9c-12405674fe2d} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 40.84 MiB (attempt to allocate chunk of 33555032 bytes), maximum: 20.00 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:114: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461f421 8. ./src/Common/HashTable/HashTable.h:522: auto DB::constructWithReserveIfPossible, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(unsigned long) @ 0x000000003034a573 9. ./build_docker/./src/Interpreters/AggregatedDataVariants.cpp:98: DB::AggregatedDataVariants::init(DB::AggregatedDataVariants::Type, std::optional) @ 0x000000003034519d 10. ./build_docker/./src/Interpreters/Aggregator.cpp:249: (anonymous namespace)::initDataVariantsWithSizeHint(DB::AggregatedDataVariants&, DB::AggregatedDataVariants::Type, DB::Aggregator::Params const&) @ 0x000000002fe5a1b2 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1551: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe62fdc 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 17. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 18. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.246671 [ 730 ] {39dbefe5-8e95-4c56-a03f-5d88d45abe33} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 20.65 MiB (attempt to allocate chunk of 1048967 bytes), maximum: 20.00 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x0000000024701dfb 9. ./src/IO/BufferWithOwnMemory.h:0: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x000000002473a644 10. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:187: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x00000000248833af 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, Poco::Net::StreamSocket&) @ 0x000000002f8f03c1 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], Poco::Net::StreamSocket&, void>(std::allocator const&, Poco::Net::StreamSocket&) @ 0x000000002f8f015e 13. ./build_docker/./src/Client/Connection.cpp:195: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x0000000033274215 14. ./build_docker/./src/Client/ConnectionEstablisher.cpp:49: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&) @ 0x0000000033296b35 15. ./build_docker/./src/Client/ConnectionEstablisher.cpp:0: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x0000000033299b58 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:13:55.246698 [ 23597 ] {b896cbb8-1dd5-4673-8391-1c9911a86a72} TCPHandler: Code: 469. DB::Exception: Constraint `c0` for table test_uhi6u1dy.constraint_on_nullable_type (9221ebaa-3fa4-41af-8612-e0a339921323) is violated at row 1. Expression: (id = 1). Column values: id = 0. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.269610 [ 23597 ] {8786d87c-e01a-4bfe-89ae-dba58908d4f6} executeQuery: Code: 469. DB::Exception: Constraint `c0` for table test_uhi6u1dy.constraint_on_low_cardinality_type (11fbb72f-21f3-40c0-8d7b-cd4d429e9c66) is violated at row 1. Expression: (id = 2). Column values: id = 0. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:48864) (comment: 01720_constraints_complex_types.sql) (in query: INSERT INTO constraint_on_low_cardinality_type VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.269771 [ 23597 ] {8786d87c-e01a-4bfe-89ae-dba58908d4f6} TCPHandler: Code: 469. DB::Exception: Constraint `c0` for table test_uhi6u1dy.constraint_on_low_cardinality_type (11fbb72f-21f3-40c0-8d7b-cd4d429e9c66) is violated at row 1. Expression: (id = 2). Column values: id = 0. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.290789 [ 23597 ] {f4e11902-a7a0-45fd-b77b-4068dcba5b88} executeQuery: Code: 469. DB::Exception: Constraint `c0` for table test_uhi6u1dy.constraint_on_low_cardinality_nullable_type (fc7d0557-ac52-48c1-ae4f-cfc8fb86d463) is violated at row 1. Expression: (id = 3). Column values: id = 0. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:48864) (comment: 01720_constraints_complex_types.sql) (in query: INSERT INTO constraint_on_low_cardinality_nullable_type VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.290896 [ 23597 ] {f4e11902-a7a0-45fd-b77b-4068dcba5b88} TCPHandler: Code: 469. DB::Exception: Constraint `c0` for table test_uhi6u1dy.constraint_on_low_cardinality_nullable_type (fc7d0557-ac52-48c1-ae4f-cfc8fb86d463) is violated at row 1. Expression: (id = 3). Column values: id = 0. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.345106 [ 22858 ] {0056dc25-b0ff-4bb1-bc11-11b4a4398083} executeQuery: Code: 43. DB::Exception: Illegal types of arguments: Map(UUID, UInt16), UInt16 for function arrayElement. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:48862) (comment: 01720_type_map_and_casts.sql) (in query: SELECT m[257], m[1] FROM table_map_with_key_integer;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::(anonymous namespace)::FunctionArrayElement::executeMap(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023884597 5. DB::(anonymous namespace)::FunctionArrayElement::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002387f15f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 13. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 15. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.345310 [ 22858 ] {0056dc25-b0ff-4bb1-bc11-11b4a4398083} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments: Map(UUID, UInt16), UInt16 for function arrayElement. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::(anonymous namespace)::FunctionArrayElement::executeMap(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000023884597 5. DB::(anonymous namespace)::FunctionArrayElement::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002387f15f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 13. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 15. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.730787 [ 22858 ] {4623df92-cf86-4d3b-80d6-b6f9cc3b4be4} executeQuery: Code: 36. DB::Exception: Type of Map key must be a type, that can be represented by integer or String or FixedString (possibly LowCardinality) or UUID or IPv6, but Float32 given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:48862) (comment: 01720_type_map_and_casts.sql) (in query: CREATE TABLE table_map_with_key_integer (`m` Map(Float32, String)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 3201, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.014298515394330025, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 59562348, compact_parts_max_bytes_to_buffer = 23199467, compact_parts_max_granules_to_buffer = 185, compact_parts_merge_max_bytes_to_prefetch_part = 10948999, merge_max_block_size = 1136, old_parts_lifetime = 419., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5150074, concurrent_part_removal_threshold = 41, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 63244, primary_key_compress_block_size = 54333), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:0: DB::DataTypeMap::assertKeyType() const @ 0x000000002f4d2764 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:56: DB::DataTypeMap::DataTypeMap(std::vector, std::allocator>> const&) @ 0x000000002f4d2a45 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>>&>(std::allocator, std::vector, std::allocator>>&) @ 0x000000001ea17f1c 7. std::shared_ptr std::allocate_shared[abi:v15000], std::vector, std::allocator>>&, void>(std::allocator const&, std::vector, std::allocator>>&) @ 0x000000001ea17c80 8. ./build_docker/./src/DataTypes/DataTypeMap.cpp:165: DB::create(std::shared_ptr const&) @ 0x000000002f4d6824 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f47c958 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b10d8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.786389 [ 22858 ] {4623df92-cf86-4d3b-80d6-b6f9cc3b4be4} TCPHandler: Code: 36. DB::Exception: Type of Map key must be a type, that can be represented by integer or String or FixedString (possibly LowCardinality) or UUID or IPv6, but Float32 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:0: DB::DataTypeMap::assertKeyType() const @ 0x000000002f4d2764 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:56: DB::DataTypeMap::DataTypeMap(std::vector, std::allocator>> const&) @ 0x000000002f4d2a45 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>>&>(std::allocator, std::vector, std::allocator>>&) @ 0x000000001ea17f1c 7. std::shared_ptr std::allocate_shared[abi:v15000], std::vector, std::allocator>>&, void>(std::allocator const&, std::vector, std::allocator>>&) @ 0x000000001ea17c80 8. ./build_docker/./src/DataTypes/DataTypeMap.cpp:165: DB::create(std::shared_ptr const&) @ 0x000000002f4d6824 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f47c958 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b10d8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.788700 [ 22858 ] {007bfdb3-5e72-4740-a921-f9cd15e659f3} executeQuery: Code: 36. DB::Exception: Type of Map key must be a type, that can be represented by integer or String or FixedString (possibly LowCardinality) or UUID or IPv6, but Nullable(String) given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:48862) (comment: 01720_type_map_and_casts.sql) (in query: CREATE TABLE table_map_with_key_integer (`m` Map(Nullable(String), String)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 3201, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.014298515394330025, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 59562348, compact_parts_max_bytes_to_buffer = 23199467, compact_parts_max_granules_to_buffer = 185, compact_parts_merge_max_bytes_to_prefetch_part = 10948999, merge_max_block_size = 1136, old_parts_lifetime = 419., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5150074, concurrent_part_removal_threshold = 41, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 63244, primary_key_compress_block_size = 54333), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:0: DB::DataTypeMap::assertKeyType() const @ 0x000000002f4d2764 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:56: DB::DataTypeMap::DataTypeMap(std::vector, std::allocator>> const&) @ 0x000000002f4d2a45 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>>&>(std::allocator, std::vector, std::allocator>>&) @ 0x000000001ea17f1c 7. std::shared_ptr std::allocate_shared[abi:v15000], std::vector, std::allocator>>&, void>(std::allocator const&, std::vector, std::allocator>>&) @ 0x000000001ea17c80 8. ./build_docker/./src/DataTypes/DataTypeMap.cpp:165: DB::create(std::shared_ptr const&) @ 0x000000002f4d6824 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f47c958 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b10d8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.788827 [ 22858 ] {007bfdb3-5e72-4740-a921-f9cd15e659f3} TCPHandler: Code: 36. DB::Exception: Type of Map key must be a type, that can be represented by integer or String or FixedString (possibly LowCardinality) or UUID or IPv6, but Nullable(String) given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:0: DB::DataTypeMap::assertKeyType() const @ 0x000000002f4d2764 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:56: DB::DataTypeMap::DataTypeMap(std::vector, std::allocator>> const&) @ 0x000000002f4d2a45 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>>&>(std::allocator, std::vector, std::allocator>>&) @ 0x000000001ea17f1c 7. std::shared_ptr std::allocate_shared[abi:v15000], std::vector, std::allocator>>&, void>(std::allocator const&, std::vector, std::allocator>>&) @ 0x000000001ea17c80 8. ./build_docker/./src/DataTypes/DataTypeMap.cpp:165: DB::create(std::shared_ptr const&) @ 0x000000002f4d6824 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f47c958 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b10d8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.790545 [ 22858 ] {e5964e0c-0cb3-4811-9eb1-f8c655b12cee} executeQuery: Code: 36. DB::Exception: Type of Map key must be a type, that can be represented by integer or String or FixedString (possibly LowCardinality) or UUID or IPv6, but Array(UInt32) given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:48862) (comment: 01720_type_map_and_casts.sql) (in query: CREATE TABLE table_map_with_key_integer (`m` Map(Array(UInt32), String)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 3201, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.014298515394330025, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 59562348, compact_parts_max_bytes_to_buffer = 23199467, compact_parts_max_granules_to_buffer = 185, compact_parts_merge_max_bytes_to_prefetch_part = 10948999, merge_max_block_size = 1136, old_parts_lifetime = 419., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5150074, concurrent_part_removal_threshold = 41, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 63244, primary_key_compress_block_size = 54333), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:0: DB::DataTypeMap::assertKeyType() const @ 0x000000002f4d2764 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:56: DB::DataTypeMap::DataTypeMap(std::vector, std::allocator>> const&) @ 0x000000002f4d2a45 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>>&>(std::allocator, std::vector, std::allocator>>&) @ 0x000000001ea17f1c 7. std::shared_ptr std::allocate_shared[abi:v15000], std::vector, std::allocator>>&, void>(std::allocator const&, std::vector, std::allocator>>&) @ 0x000000001ea17c80 8. ./build_docker/./src/DataTypes/DataTypeMap.cpp:165: DB::create(std::shared_ptr const&) @ 0x000000002f4d6824 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f47c958 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b10d8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.790666 [ 22858 ] {e5964e0c-0cb3-4811-9eb1-f8c655b12cee} TCPHandler: Code: 36. DB::Exception: Type of Map key must be a type, that can be represented by integer or String or FixedString (possibly LowCardinality) or UUID or IPv6, but Array(UInt32) given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:0: DB::DataTypeMap::assertKeyType() const @ 0x000000002f4d2764 5. ./build_docker/./src/DataTypes/DataTypeMap.cpp:56: DB::DataTypeMap::DataTypeMap(std::vector, std::allocator>> const&) @ 0x000000002f4d2a45 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>>&>(std::allocator, std::vector, std::allocator>>&) @ 0x000000001ea17f1c 7. std::shared_ptr std::allocate_shared[abi:v15000], std::vector, std::allocator>>&, void>(std::allocator const&, std::vector, std::allocator>>&) @ 0x000000001ea17c80 8. ./build_docker/./src/DataTypes/DataTypeMap.cpp:165: DB::create(std::shared_ptr const&) @ 0x000000002f4d6824 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f47c958 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b10d8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.791952 [ 23611 ] {57cd9393-9dd9-42dc-9e34-e277d9bac014} executeQuery: Code: 153. DB::Exception: Cannot perform integer division, because it will produce infinite or too large number: In scope SELECT intDiv(18446744073709551615, 0.9998999834060669). (ILLEGAL_DIVISION) (version 24.3.12.76.altinitystable) (from [::1]:48916) (comment: 01717_int_div_float_too_large_ubsan.sql) (in query: SELECT intDiv(18446744073709551615, 0.9998999834060669);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x000000001cf927f2 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d2aef87 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001d2ae942 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d251e8c 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d24d3ac 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d24a585 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d2484b1 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:13:55.792611 [ 23611 ] {57cd9393-9dd9-42dc-9e34-e277d9bac014} TCPHandler: Code: 153. DB::Exception: Cannot perform integer division, because it will produce infinite or too large number: In scope SELECT intDiv(18446744073709551615, 0.9998999834060669). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x000000001cf927f2 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d2aef87 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001d2ae942 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d251e8c 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d24d3ac 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d24a585 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d2484b1 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:13:55.814123 [ 23611 ] {ef152433-5957-4262-a728-876351cccf2a} executeQuery: Code: 153. DB::Exception: Cannot perform integer division, because it will produce infinite or too large number: In scope SELECT intDiv(18446744073709551615, 1.). (ILLEGAL_DIVISION) (version 24.3.12.76.altinitystable) (from [::1]:48916) (comment: 01717_int_div_float_too_large_ubsan.sql) (in query: SELECT intDiv(18446744073709551615, 1.);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x000000001cf927f2 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d2aef87 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001d2ae942 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d251e8c 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d24d3ac 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d24a585 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d2484b1 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:13:55.814350 [ 23611 ] {ef152433-5957-4262-a728-876351cccf2a} TCPHandler: Code: 153. DB::Exception: Cannot perform integer division, because it will produce infinite or too large number: In scope SELECT intDiv(18446744073709551615, 1.). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x000000001cf927f2 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d2aef87 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001d2ae942 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d251e8c 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d24d3ac 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d24a585 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d2484b1 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:13:55.814503 [ 23586 ] {d68f0e93-755c-49a6-a2cd-7fc5f68041d2} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'tabB' in scope SELECT date, if(colA IN (SELECT colB FROM tabC), 0, colA) AS colX FROM tabB. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48966) (comment: 01717_global_with_subquery_fix.sql) (in query: WITH (SELECT count(distinct colU) from tabA) AS withA, (SELECT count(distinct colU) from tabA) AS withB SELECT withA / withB AS ratio FROM (SELECT date AS period, colX FROM (SELECT date, if(colA IN (SELECT colB FROM tabC), 0, colA) AS colX FROM tabB) AS tempB GROUP BY period, colX) AS main;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6519: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882639 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7911: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd42 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6519: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882639 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7911: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd42 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:55.814730 [ 23586 ] {d68f0e93-755c-49a6-a2cd-7fc5f68041d2} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'tabB' in scope SELECT date, if(colA IN (SELECT colB FROM tabC), 0, colA) AS colX FROM tabB. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6519: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882639 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7911: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd42 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6519: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882639 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7911: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd42 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:56.280835 [ 23621 ] {33d6336b-953c-42fe-9769-02d3bfea7448} executeQuery: Code: 36. DB::Exception: Table TTL is not allowed for MergeTree in old syntax. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49026) (comment: 01713_table_ttl_old_syntax_zookeeper.sql) (in query: CREATE TABLE ttl_table ( date Date, value UInt64 ) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_01713_table_ttl', '1', date, date, 8192) TTL date + INTERVAL 2 MONTH;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306ecc0 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:56.281004 [ 23621 ] {33d6336b-953c-42fe-9769-02d3bfea7448} TCPHandler: Code: 36. DB::Exception: Table TTL is not allowed for MergeTree in old syntax. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306ecc0 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:56.300158 [ 23621 ] {9c56f536-2631-4815-877a-e7dc1fae373b} executeQuery: Code: 42. DB::Exception: With extended storage definition syntax storage ReplicatedMergeTree requires 0 to 2 parameters: [path in ZooKeeper], [replica name] Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/en/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/en/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:49026) (comment: 01713_table_ttl_old_syntax_zookeeper.sql) (in query: CREATE TABLE ttl_table (`date` Date, `value` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_01713_table_ttl', '1', date, date, 8192) PARTITION BY date SETTINGS index_granularity = 27324, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 111194695, compact_parts_max_granules_to_buffer = 19, compact_parts_merge_max_bytes_to_prefetch_part = 11130585, merge_max_block_size = 19269, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1755221179, index_granularity_bytes = 27398354, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 97049, primary_key_compress_block_size = 62445), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x0000000033072cd1 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:260: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000033066945 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:56.300469 [ 23621 ] {9c56f536-2631-4815-877a-e7dc1fae373b} TCPHandler: Code: 42. DB::Exception: With extended storage definition syntax storage ReplicatedMergeTree requires 0 to 2 parameters: [path in ZooKeeper], [replica name] Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/en/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/en/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x0000000033072cd1 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:260: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000033066945 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:56.302974 [ 23621 ] {e5686b86-b396-4ab5-8fcc-792900809b09} executeQuery: Code: 42. DB::Exception: With extended storage definition syntax storage ReplicatedMergeTree requires 0 to 2 parameters: [path in ZooKeeper], [replica name] Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/en/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/en/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:49026) (comment: 01713_table_ttl_old_syntax_zookeeper.sql) (in query: CREATE TABLE ttl_table (`date` Date, `value` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_01713_table_ttl', '1', date, date, 8192) ORDER BY value SETTINGS index_granularity = 27324, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 111194695, compact_parts_max_granules_to_buffer = 19, compact_parts_merge_max_bytes_to_prefetch_part = 11130585, merge_max_block_size = 19269, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1755221179, index_granularity_bytes = 27398354, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 97049, primary_key_compress_block_size = 62445), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x0000000033072cd1 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:260: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000033066945 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:56.303114 [ 23621 ] {e5686b86-b396-4ab5-8fcc-792900809b09} TCPHandler: Code: 42. DB::Exception: With extended storage definition syntax storage ReplicatedMergeTree requires 0 to 2 parameters: [path in ZooKeeper], [replica name] Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/en/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/en/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x0000000033072cd1 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:260: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000033066945 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:57.391519 [ 23610 ] {a344ad0f-6fc9-4827-a9ad-19f4d00e01f8} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:49402) (comment: 01710_projections.sql) (in query: select * from projection_test;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003400a5aa 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000033f10c66 6. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f1012e 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:57.391541 [ 48606 ] {6fbf814b-0ebf-475d-aaac-3a57679183ed} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:49278) (comment: 01710_minmax_count_projection.sql) (in query: select count(if(d=4, Null, 1)) from test settings force_optimize_projection = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003400a5aa 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000033f10c66 6. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f1012e 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:57.391726 [ 48606 ] {6fbf814b-0ebf-475d-aaac-3a57679183ed} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003400a5aa 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000033f10c66 6. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f1012e 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:57.391762 [ 23610 ] {a344ad0f-6fc9-4827-a9ad-19f4d00e01f8} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003400a5aa 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000033f10c66 6. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f1012e 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:57.397318 [ 23610 ] {b63b7b43-063a-4fc3-a676-0d14c1e4eee6} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:49402) (comment: 01710_projections.sql) (in query: select toStartOfMinute(datetime) dt_m, countIf(first_time = 0) from projection_test join (select 1) x on 1 where domain = '1' group by dt_m order by dt_m;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003400a5aa 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000033f10c66 6. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f1012e 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:57.397456 [ 23610 ] {b63b7b43-063a-4fc3-a676-0d14c1e4eee6} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003400a5aa 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000033f10c66 6. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f1012e 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:58.052568 [ 1346 ] {3888bc14-751f-4b96-b09e-efb8534d5ad5::202504_2_2_0_3} MutatePlainMergeTreeTask: Code: 236. DB::Exception: Cancelled mutating parts. (ABORTED) (version 24.3.12.76.altinitystable) 2025.03.05 21:13:58.064975 [ 1346 ] {3888bc14-751f-4b96-b09e-efb8534d5ad5::202504_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 236. DB::Exception: Cancelled mutating parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:58: DB::MutationHelpers::checkOperationIsNotCanceled(DB::ActionBlocker&, DB::BackgroundProcessListEntry*) @ 0x0000000032e82cd6 5. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::prepare() @ 0x0000000032e83f83 6. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2000: DB::MutateTask::execute() @ 0x0000000032e83d41 7. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:0: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000330e97fe 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032addf0f 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032adec9e 10. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 11. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:13:58.611674 [ 23635 ] {a4fba538-b1f5-4dda-861b-d182b122331a} executeQuery: Code: 252. DB::Exception: Too many inactive parts (2) in table 'test_51g6pl0j.data_01709 (94387bf7-7e06-4d79-81ef-194edc0ae001)'. Parts cleaning are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.3.12.76.altinitystable) (from [::1]:49836) (comment: 01709_inactive_parts_to_throw_insert.sql) (in query: insert into data_01709 values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000032b6f419 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51656 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 9. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 10. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x0000000033579d62 11. ./contrib/llvm-project/libcxx/include/vector:537: DB::TCPHandler::processInsertQuery() @ 0x000000003349ec9c 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:58.611779 [ 23635 ] {a4fba538-b1f5-4dda-861b-d182b122331a} TCPHandler: Code: 252. DB::Exception: Too many inactive parts (2) in table 'test_51g6pl0j.data_01709 (94387bf7-7e06-4d79-81ef-194edc0ae001)'. Parts cleaning are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000187cb293 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000032b6f419 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51656 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 9. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 10. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x0000000033579d62 11. ./contrib/llvm-project/libcxx/include/vector:537: DB::TCPHandler::processInsertQuery() @ 0x000000003349ec9c 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:13:59.218043 [ 34946 ] {0174e8b6-5c2e-4866-9fd0-66a099ebef23} executeQuery: Code: 386. DB::Exception: There is no supertype for types Tuple(Array(UInt8), UInt8), Tuple(Array(UInt8), UInt8, String, String, UInt8) because Tuples have different sizes: In scope SELECT if(xxx = 'x', ([2], 3), ([3], 4, 'q', 'w', 7)) FROM agg_table. (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:46200) (comment: 01701_if_tuple_segfault.sql) (in query: SELECT if(xxx = 'x', ([2], 3), ([3], 4, 'q', 'w', 7)) FROM agg_table;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:323: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ed99 6. ./build_docker/./src/Functions/if.cpp:0: DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000309dac0a 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:13:59.218990 [ 34946 ] {0174e8b6-5c2e-4866-9fd0-66a099ebef23} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Tuple(Array(UInt8), UInt8), Tuple(Array(UInt8), UInt8, String, String, UInt8) because Tuples have different sizes: In scope SELECT if(xxx = 'x', ([2], 3), ([3], 4, 'q', 'w', 7)) FROM agg_table. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:323: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ed99 6. ./build_docker/./src/Functions/if.cpp:0: DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000309dac0a 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:13:59.325089 [ 48605 ] {29df9b0d-ab78-4fec-8278-ce94e1839af0} executeQuery: Code: 128. DB::Exception: Function mapPopulateSeries too large array size in the result: In scope SELECT mapPopulateSeries([toUInt64(1)], [1], 18446744073709551615). (TOO_LARGE_ARRAY_SIZE) (version 24.3.12.76.altinitystable) (from [::1]:46224) (comment: 01698_map_populate_overflow.sql) (in query: SELECT mapPopulateSeries([toUInt64(1)], [1], 0xFFFFFFFFFFFFFFFF);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::FunctionMapPopulateSeries::executeImplTyped(COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::mutable_ptr, COW::mutable_ptr, COW::mutable_ptr) const @ 0x00000000243131e6 5. auto DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator(), DB::DataTypeNumber>>(auto const&) const @ 0x0000000024311f2d 6. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002424db13 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:13:59.325306 [ 48605 ] {29df9b0d-ab78-4fec-8278-ce94e1839af0} TCPHandler: Code: 128. DB::Exception: Function mapPopulateSeries too large array size in the result: In scope SELECT mapPopulateSeries([toUInt64(1)], [1], 18446744073709551615). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. void DB::FunctionMapPopulateSeries::executeImplTyped(COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::mutable_ptr, COW::mutable_ptr, COW::mutable_ptr) const @ 0x00000000243131e6 5. auto DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator(), DB::DataTypeNumber>>(auto const&) const @ 0x0000000024311f2d 6. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002424db13 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:14:00.837143 [ 14920 ] {8e42e1ab-2b36-4370-90fe-0c988762bbed} executeQuery: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitAnd: In scope SELECT bitAnd(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:46726) (comment: 01677_bit_float.sql) (in query: SELECT bitAnd(0, inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001996f514 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:00.837279 [ 14920 ] {8e42e1ab-2b36-4370-90fe-0c988762bbed} TCPHandler: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitAnd: In scope SELECT bitAnd(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001996f514 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:00.863917 [ 14920 ] {77ece5bd-1e60-44f3-9f2e-747897c58277} executeQuery: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitXor: In scope SELECT bitXor(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:46726) (comment: 01677_bit_float.sql) (in query: SELECT bitXor(0, inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a86c014 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:00.864156 [ 14920 ] {77ece5bd-1e60-44f3-9f2e-747897c58277} TCPHandler: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitXor: In scope SELECT bitXor(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a86c014 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:00.866848 [ 14920 ] {b011a6a0-93f8-40ae-9d90-0151afc8135e} executeQuery: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitOr: In scope SELECT bitOr(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:46726) (comment: 01677_bit_float.sql) (in query: SELECT bitOr(0, inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019ff5f94 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:00.866980 [ 14920 ] {b011a6a0-93f8-40ae-9d90-0151afc8135e} TCPHandler: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitOr: In scope SELECT bitOr(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000019ff5f94 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:00.868470 [ 14920 ] {b957b46e-aca9-43e1-b2db-81493b525ef8} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitTest: In scope SELECT bitTest(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:46726) (comment: 01677_bit_float.sql) (in query: SELECT bitTest(inf, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a6f2a94 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:00.868580 [ 14920 ] {b957b46e-aca9-43e1-b2db-81493b525ef8} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitTest: In scope SELECT bitTest(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a6f2a94 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:00.870208 [ 14920 ] {3fe7bf36-41a0-451d-9c17-9a4b683827c0} executeQuery: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitTest: In scope SELECT bitTest(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:46726) (comment: 01677_bit_float.sql) (in query: SELECT bitTest(0, inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a6f2a94 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:00.870331 [ 14920 ] {3fe7bf36-41a0-451d-9c17-9a4b683827c0} TCPHandler: Code: 43. DB::Exception: Illegal types UInt8 and Float64 of arguments of function bitTest: In scope SELECT bitTest(0, inf). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a6f2a94 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:00.871514 [ 14920 ] {3af0549f-8b48-4ac5-8264-59802a855092} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateLeft: In scope SELECT bitRotateLeft(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:46726) (comment: 01677_bit_float.sql) (in query: SELECT bitRotateLeft(inf, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a14aff4 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:00.871619 [ 14920 ] {3af0549f-8b48-4ac5-8264-59802a855092} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateLeft: In scope SELECT bitRotateLeft(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a14aff4 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:00.904055 [ 14920 ] {7b7bd522-4635-48ec-96cc-485b2a8d25b9} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateRight: In scope SELECT bitRotateRight(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:46726) (comment: 01677_bit_float.sql) (in query: SELECT bitRotateRight(inf, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a2a0054 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:00.904330 [ 14920 ] {7b7bd522-4635-48ec-96cc-485b2a8d25b9} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateRight: In scope SELECT bitRotateRight(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a2a0054 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:00.907223 [ 14920 ] {d6f5cc7a-a9e4-4e9e-8869-f9e22ee23851} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftLeft: In scope SELECT bitShiftLeft(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:46726) (comment: 01677_bit_float.sql) (in query: SELECT bitShiftLeft(inf, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a417c74 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:00.907360 [ 14920 ] {d6f5cc7a-a9e4-4e9e-8869-f9e22ee23851} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftLeft: In scope SELECT bitShiftLeft(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a417c74 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:00.933542 [ 14920 ] {7fcf4ee3-2ca4-47c6-ae05-7752b7706807} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftRight: In scope SELECT bitShiftRight(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:46726) (comment: 01677_bit_float.sql) (in query: SELECT bitShiftRight(inf, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a58f954 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:00.933723 [ 14920 ] {7fcf4ee3-2ca4-47c6-ae05-7752b7706807} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftRight: In scope SELECT bitShiftRight(inf, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a58f954 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:01.850543 [ 34946 ] {e4354bfd-ed98-4cc1-a930-8d79faaf26d3} executeQuery: Code: 43. DB::Exception: Cannot reinterpret String as FixedString because it is not fixed size and contiguous in memory: In scope SELECT reinterpret('123', 'FixedString(1)'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:46908) (comment: 01676_reinterpret_as.sql) (in query: SELECT reinterpret('123', 'FixedString(1)');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionReinterpret::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213d1ed8 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:01.850727 [ 34946 ] {e4354bfd-ed98-4cc1-a930-8d79faaf26d3} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret String as FixedString because it is not fixed size and contiguous in memory: In scope SELECT reinterpret('123', 'FixedString(1)'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionReinterpret::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213d1ed8 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:03.204200 [ 48600 ] {5b8678a9-62ee-4dae-8e3d-b4546e39c9bd} executeQuery: Code: 59. DB::Exception: Invalid type for filter in WHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE x != 0 WHERE arr. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.3.12.76.altinitystable) (from [::1]:47114) (comment: 01674_where_prewhere_array_crash.sql) (in query: select x from tab array join arr prewhere x != 0 where arr;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002f119af1 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003093a14b 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:57: DB::validateFilters(std::shared_ptr const&) @ 0x0000000030939c1e 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875940 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:03.204396 [ 48600 ] {5b8678a9-62ee-4dae-8e3d-b4546e39c9bd} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in WHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE x != 0 WHERE arr. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002f119af1 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003093a14b 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:57: DB::validateFilters(std::shared_ptr const&) @ 0x0000000030939c1e 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875940 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:03.250851 [ 48600 ] {24ce3eb3-dd9b-405c-b019-f24e2d9ad1e3} executeQuery: Code: 59. DB::Exception: Invalid type for filter in PREWHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE arr WHERE x != 0. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.3.12.76.altinitystable) (from [::1]:47114) (comment: 01674_where_prewhere_array_crash.sql) (in query: select x from tab array join arr prewhere arr where x != 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002f119af1 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003093a14b 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:47: DB::validateFilters(std::shared_ptr const&) @ 0x0000000030939ae9 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875940 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:03.254094 [ 48600 ] {24ce3eb3-dd9b-405c-b019-f24e2d9ad1e3} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in PREWHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE arr WHERE x != 0. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002f119af1 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003093a14b 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:47: DB::validateFilters(std::shared_ptr const&) @ 0x0000000030939ae9 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875940 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:03.688846 [ 23628 ] {de60cba6-05ec-487e-97d1-62450682b5dc} executeQuery: Code: 117. DB::Exception: Incorrect data: Sign = -117 (must be 1 or -1). (INCORRECT_DATA) (version 24.3.12.76.altinitystable) (from [::1]:47176) (comment: 01679_incorrect_data_on_insert_collapsing.sh) (in query: INSERT INTO collapsing_merge_tree VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:0: DB::CollapsingSortedAlgorithm::merge() @ 0x0000000033d2ca26 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:386: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000032ecaed7 6. ./contrib/llvm-project/libcxx/include/vector:951: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000032ecc814 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:404: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032ecb650 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:86: DB::MergeTreeSink::consume(DB::Chunk) @ 0x00000000330e0419 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 15. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:03.689680 [ 23628 ] {de60cba6-05ec-487e-97d1-62450682b5dc} TCPHandler: Code: 117. DB::Exception: Incorrect data: Sign = -117 (must be 1 or -1). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:0: DB::CollapsingSortedAlgorithm::merge() @ 0x0000000033d2ca26 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:386: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000032ecaed7 6. ./contrib/llvm-project/libcxx/include/vector:951: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000032ecc814 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:404: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032ecb650 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:86: DB::MergeTreeSink::consume(DB::Chunk) @ 0x00000000330e0419 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 15. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:07.214001 [ 1474 ] {139dbf19-7d84-4dd7-a8c9-24500ba4d66a} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000026 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:07.214294 [ 1474 ] {139dbf19-7d84-4dd7-a8c9-24500ba4d66a} DDLWorker: Query /* ddl_entry=query-0000000026 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:07.247578 [ 64953 ] {e59a780e-877e-4bab-adc6-80c40aeafed5} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:47718) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:07.247817 [ 64953 ] {e59a780e-877e-4bab-adc6-80c40aeafed5} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:07.668558 [ 1474 ] {b6e10427-983b-497a-bab1-bf01b100db4e} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000027 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:07.668771 [ 1474 ] {b6e10427-983b-497a-bab1-bf01b100db4e} DDLWorker: Query /* ddl_entry=query-0000000027 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:07.717522 [ 48581 ] {08999c52-27cd-4ec0-a32c-5ad61ccb6f94} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:47822) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:07.717751 [ 48581 ] {08999c52-27cd-4ec0-a32c-5ad61ccb6f94} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:08.589899 [ 1474 ] {f773e10b-1d14-496d-a184-248859db6a4c} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000029 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:08.590093 [ 1474 ] {f773e10b-1d14-496d-a184-248859db6a4c} DDLWorker: Query /* ddl_entry=query-0000000029 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:08.639645 [ 3522 ] {8fa70989-6908-4c79-9f0d-7655dfcbfdd2} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48028) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:08.639919 [ 3522 ] {8fa70989-6908-4c79-9f0d-7655dfcbfdd2} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:08.699033 [ 48602 ] {b5b6a519-1614-4284-9a2c-460baac65060} executeQuery: Code: 403. DB::Exception: JOIN (SELECT 'a' AS a, 'b' AS b, 'c' AS c, 'd' AS d, 'e' AS e, 'f' AS f FROM system.one AS __table2) AS __table1 ALL LEFT JOIN (SELECT 'a' AS a, 'b' AS b, 'c' AS c, 'd' AS d, 'e' AS e, 'f' AS f FROM system.one AS __table4) AS __table3 ON ((__table1.d = __table3.b) OR (__table1.c = __table3.b) OR ((__table1.d = __table3.b) AND (__table1.d = __table3.b))) OR ((__table1.e = __table3.e) AND (__table1.a = __table3.a) AND (__table3.f = __table1.f)) join expression contains column from left and right table. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:48016) (comment: 01661_join_complex.sql) (in query: select * from (select 'a' as a, 'b' as b, 'c' as c, 'd' as d, 'e' as e, 'f' as f) as t1 left join (select 'a' as a, 'b' as b, 'c' as c, 'd' as d, 'e' as e, 'f' as f) as t2 on (t1.d = t2.b or t1.c = t2.b or t1.d = t2.b and t1.d = t2.b) or (t1.e = t2.e and t1.a=t2.a and t2.f=t1.f);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::extractJoinTableSideFromExpression(DB::IQueryTreeNode const*, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&) @ 0x000000003109d6ca 5. ./build_docker/./src/Planner/PlannerJoins.cpp:364: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bd25 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000031096d13 7. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 9. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:08.699312 [ 48602 ] {b5b6a519-1614-4284-9a2c-460baac65060} TCPHandler: Code: 403. DB::Exception: JOIN (SELECT 'a' AS a, 'b' AS b, 'c' AS c, 'd' AS d, 'e' AS e, 'f' AS f FROM system.one AS __table2) AS __table1 ALL LEFT JOIN (SELECT 'a' AS a, 'b' AS b, 'c' AS c, 'd' AS d, 'e' AS e, 'f' AS f FROM system.one AS __table4) AS __table3 ON ((__table1.d = __table3.b) OR (__table1.c = __table3.b) OR ((__table1.d = __table3.b) AND (__table1.d = __table3.b))) OR ((__table1.e = __table3.e) AND (__table1.a = __table3.a) AND (__table3.f = __table1.f)) join expression contains column from left and right table. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::extractJoinTableSideFromExpression(DB::IQueryTreeNode const*, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&) @ 0x000000003109d6ca 5. ./build_docker/./src/Planner/PlannerJoins.cpp:364: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bd25 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000031096d13 7. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 9. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:08.704381 [ 48602 ] {04b2d101-cba4-4c1d-851c-7f457a85a108} executeQuery: Code: 403. DB::Exception: JOIN (SELECT 'a' AS a, 'b' AS b, 'c' AS c, 'd' AS d, 'e' AS e, 'f' AS f FROM system.one AS __table2) AS __table1 ALL RIGHT JOIN (SELECT 'a' AS a, 'b' AS b, 'c' AS c, 'd' AS d, 'e' AS e, 'f' AS f FROM system.one AS __table4) AS __table3 ON ((__table1.d = __table3.b) OR (__table1.c = __table3.b)) OR (__table1.e = __table3.e) join expression contains column from left and right table. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:48016) (comment: 01661_join_complex.sql) (in query: select * from (select 'a' as a, 'b' as b, 'c' as c, 'd' as d, 'e' as e, 'f' as f) as t1 right join (select 'a' as a, 'b' as b, 'c' as c, 'd' as d, 'e' as e, 'f' as f) as t2 on (t1.d = t2.b or t1.c = t2.b) or t1.e = t2.e;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::extractJoinTableSideFromExpression(DB::IQueryTreeNode const*, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&) @ 0x000000003109d6ca 5. ./build_docker/./src/Planner/PlannerJoins.cpp:364: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bd25 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000031096d13 7. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 9. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:08.704568 [ 48602 ] {04b2d101-cba4-4c1d-851c-7f457a85a108} TCPHandler: Code: 403. DB::Exception: JOIN (SELECT 'a' AS a, 'b' AS b, 'c' AS c, 'd' AS d, 'e' AS e, 'f' AS f FROM system.one AS __table2) AS __table1 ALL RIGHT JOIN (SELECT 'a' AS a, 'b' AS b, 'c' AS c, 'd' AS d, 'e' AS e, 'f' AS f FROM system.one AS __table4) AS __table3 ON ((__table1.d = __table3.b) OR (__table1.c = __table3.b)) OR (__table1.e = __table3.e) join expression contains column from left and right table. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::extractJoinTableSideFromExpression(DB::IQueryTreeNode const*, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&) @ 0x000000003109d6ca 5. ./build_docker/./src/Planner/PlannerJoins.cpp:364: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bd25 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000031096d13 7. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 9. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:08.709316 [ 48602 ] {64bd1f75-1a34-4c11-b550-3ab4669036b4} executeQuery: Code: 403. DB::Exception: JOIN (SELECT 'a' AS a, 'b' AS b, 'c' AS c, 'd' AS d, 'e' AS e, 'f' AS f FROM system.one AS __table2) AS __table1 ALL INNER JOIN (SELECT 'a' AS a, 'b' AS b, 'c' AS c, 'd' AS d, 'e' AS e, 'f' AS f FROM system.one AS __table4) AS __table3 ON ((__table1.d = __table3.b) OR (__table1.c = __table3.b)) OR ((__table1.e = __table3.e) AND (__table1.a = __table3.a) AND (__table3.f = __table1.f)) join expression contains column from left and right table. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:48016) (comment: 01661_join_complex.sql) (in query: select * from (select 'a' as a, 'b' as b, 'c' as c, 'd' as d, 'e' as e, 'f' as f) as t1 inner join (select 'a' as a, 'b' as b, 'c' as c, 'd' as d, 'e' as e, 'f' as f) as t2 on (t1.d = t2.b or t1.c = t2.b) or (t1.e = t2.e and t1.a=t2.a and t2.f=t1.f);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::extractJoinTableSideFromExpression(DB::IQueryTreeNode const*, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&) @ 0x000000003109d6ca 5. ./build_docker/./src/Planner/PlannerJoins.cpp:364: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bd25 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000031096d13 7. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 9. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:08.709531 [ 48602 ] {64bd1f75-1a34-4c11-b550-3ab4669036b4} TCPHandler: Code: 403. DB::Exception: JOIN (SELECT 'a' AS a, 'b' AS b, 'c' AS c, 'd' AS d, 'e' AS e, 'f' AS f FROM system.one AS __table2) AS __table1 ALL INNER JOIN (SELECT 'a' AS a, 'b' AS b, 'c' AS c, 'd' AS d, 'e' AS e, 'f' AS f FROM system.one AS __table4) AS __table3 ON ((__table1.d = __table3.b) OR (__table1.c = __table3.b)) OR ((__table1.e = __table3.e) AND (__table1.a = __table3.a) AND (__table3.f = __table1.f)) join expression contains column from left and right table. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::extractJoinTableSideFromExpression(DB::IQueryTreeNode const*, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&) @ 0x000000003109d6ca 5. ./build_docker/./src/Planner/PlannerJoins.cpp:364: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bd25 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000031096d13 7. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 9. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:08.735403 [ 48602 ] {da5f4815-b0e7-4a54-a4d1-f407b6abc238} executeQuery: Code: 403. DB::Exception: JOIN (SELECT 'a' AS a, 'b' AS b, 'c' AS c, 'd' AS d, 'e' AS e, 'f' AS f FROM system.one AS __table2) AS __table1 ALL INNER JOIN (SELECT 'a' AS a, 'b' AS b, 'c' AS c, 'd' AS d, 'e' AS e, 'f' AS f FROM system.one AS __table4) AS __table3 ON ((__table1.d = __table3.b) OR (__table1.c = __table3.b)) AND ((__table1.e = __table3.e) OR (__table1.f = __table3.f)) join expression contains column from left and right table. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:48016) (comment: 01661_join_complex.sql) (in query: select * from (select 'a' as a, 'b' as b, 'c' as c, 'd' as d, 'e' as e, 'f' as f) as t1 inner join (select 'a' as a, 'b' as b, 'c' as c, 'd' as d, 'e' as e, 'f' as f) as t2 on (t1.d = t2.b or t1.c = t2.b) and (t1.e = t2.e or t1.f=t2.f);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::extractJoinTableSideFromExpression(DB::IQueryTreeNode const*, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&) @ 0x000000003109d6ca 5. ./build_docker/./src/Planner/PlannerJoins.cpp:364: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bd25 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bf95 7. ./build_docker/./src/Planner/PlannerJoins.cpp:511: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310938de 8. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:08.735780 [ 48602 ] {da5f4815-b0e7-4a54-a4d1-f407b6abc238} TCPHandler: Code: 403. DB::Exception: JOIN (SELECT 'a' AS a, 'b' AS b, 'c' AS c, 'd' AS d, 'e' AS e, 'f' AS f FROM system.one AS __table2) AS __table1 ALL INNER JOIN (SELECT 'a' AS a, 'b' AS b, 'c' AS c, 'd' AS d, 'e' AS e, 'f' AS f FROM system.one AS __table4) AS __table3 ON ((__table1.d = __table3.b) OR (__table1.c = __table3.b)) AND ((__table1.e = __table3.e) OR (__table1.f = __table3.f)) join expression contains column from left and right table. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::extractJoinTableSideFromExpression(DB::IQueryTreeNode const*, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&) @ 0x000000003109d6ca 5. ./build_docker/./src/Planner/PlannerJoins.cpp:364: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bd25 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bf95 7. ./build_docker/./src/Planner/PlannerJoins.cpp:511: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310938de 8. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:08.895497 [ 1474 ] {a2fc8b11-6584-4adf-8d47-c9b908f455f5} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000030 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:08.895709 [ 1474 ] {a2fc8b11-6584-4adf-8d47-c9b908f455f5} DDLWorker: Query /* ddl_entry=query-0000000030 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:08.945349 [ 48581 ] {0bb29750-574d-4134-8767-c7d1ef5dd692} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48122) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:08.945593 [ 48581 ] {0bb29750-574d-4134-8767-c7d1ef5dd692} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:08.996928 [ 48605 ] {e9f0276e-d248-4074-b34d-3afab57fa6b5} executeQuery: Code: 128. DB::Exception: Too many matches per row (> 1000) in the result of function extractAllGroupsHorizontal: while executing 'FUNCTION extractAllGroupsHorizontal(repeat('abcdefghijklmnopqrstuvwxyz'_String, multiply(__table1.number, 100_UInt8)) : 2, '(\\w)'_String :: 3) -> extractAllGroupsHorizontal(repeat('abcdefghijklmnopqrstuvwxyz'_String, multiply(__table1.number, 100_UInt8)), '(\\w)'_String) Array(Array(String)) : 0'. (TOO_LARGE_ARRAY_SIZE) (version 24.3.12.76.altinitystable) (from [::1]:47944) (comment: 01661_extract_all_groups_throw_fast.sql) (in query: SELECT repeat('abcdefghijklmnopqrstuvwxyz', number * 100) AS haystack, extractAllGroupsHorizontal(haystack, '(\\w)') AS matches FROM numbers(1023);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception const&, String>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, String&&) @ 0x000000001b8667f3 4. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86566d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:08.997100 [ 48605 ] {e9f0276e-d248-4074-b34d-3afab57fa6b5} TCPHandler: Code: 128. DB::Exception: Too many matches per row (> 1000) in the result of function extractAllGroupsHorizontal: while executing 'FUNCTION extractAllGroupsHorizontal(repeat('abcdefghijklmnopqrstuvwxyz'_String, multiply(__table1.number, 100_UInt8)) : 2, '(\\w)'_String :: 3) -> extractAllGroupsHorizontal(repeat('abcdefghijklmnopqrstuvwxyz'_String, multiply(__table1.number, 100_UInt8)), '(\\w)'_String) Array(Array(String)) : 0'. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception const&, String>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, String&&) @ 0x000000001b8667f3 4. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86566d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:09.767552 [ 1474 ] {8354f442-0e6e-44bc-8c67-e5ccfba2d56e} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000033 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:09.767820 [ 1474 ] {8354f442-0e6e-44bc-8c67-e5ccfba2d56e} DDLWorker: Query /* ddl_entry=query-0000000033 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:09.816671 [ 23642 ] {4a31d707-91fa-4445-b92b-50e1b0476783} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:56562) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:09.816884 [ 23642 ] {4a31d707-91fa-4445-b92b-50e1b0476783} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:10.396747 [ 23622 ] {3a601bfa-ebe2-4f43-8006-7830bc726cf2} executeQuery: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10)). (INCORRECT_DATA) (version 24.3.12.76.altinitystable) (from [::1]:56714) (comment: 01659_h3_buffer_overflow.sql) (in query: SELECT h3HexRing(0xFFFFFFFFFFFFFF, toUInt16(10)) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, int const&, unsigned int&) @ 0x000000001cd59428 4. DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd581a9 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:14:10.396981 [ 23622 ] {3a601bfa-ebe2-4f43-8006-7830bc726cf2} TCPHandler: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10)). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, int const&, unsigned int&) @ 0x000000001cd59428 4. DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd581a9 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:14:10.399421 [ 23622 ] {89f99d16-7c1b-429e-aead-5adac0c56fa6} executeQuery: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10000, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10000)). (INCORRECT_DATA) (version 24.3.12.76.altinitystable) (from [::1]:56714) (comment: 01659_h3_buffer_overflow.sql) (in query: SELECT h3HexRing(0xFFFFFFFFFFFFFF, toUInt16(10000)) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, int const&, unsigned int&) @ 0x000000001cd59428 4. DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd581a9 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:14:10.399537 [ 23622 ] {89f99d16-7c1b-429e-aead-5adac0c56fa6} TCPHandler: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10000, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10000)). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, int const&, unsigned int&) @ 0x000000001cd59428 4. DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd581a9 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:14:10.668234 [ 1474 ] {a67db5fd-05a6-44d1-b51a-0c8564519ab4} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000036 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:10.668387 [ 1474 ] {a67db5fd-05a6-44d1-b51a-0c8564519ab4} DDLWorker: Query /* ddl_entry=query-0000000036 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:10.719084 [ 10241 ] {270e059f-e05f-4b27-b0ab-88d34e2f0b70} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:56848) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:10.719453 [ 10241 ] {270e059f-e05f-4b27-b0ab-88d34e2f0b70} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:11.563501 [ 1474 ] {89afba6b-0fe2-4075-b52e-0cd17af5c81e} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000039 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:11.563696 [ 1474 ] {89afba6b-0fe2-4075-b52e-0cd17af5c81e} DDLWorker: Query /* ddl_entry=query-0000000039 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:11.613427 [ 23611 ] {9ac892a3-d020-4a77-83bf-91685c72bdc3} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:57084) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:11.613768 [ 23611 ] {9ac892a3-d020-4a77-83bf-91685c72bdc3} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:12.145093 [ 1474 ] {7619955a-4f4c-471a-a8f6-b3a6859d778e} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000041 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:12.145278 [ 1474 ] {7619955a-4f4c-471a-a8f6-b3a6859d778e} DDLWorker: Query /* ddl_entry=query-0000000041 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:12.196093 [ 22859 ] {cc993e93-2c6c-4221-a330-2aed1ddfa044} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:57218) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:12.196452 [ 22859 ] {cc993e93-2c6c-4221-a330-2aed1ddfa044} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:12.431258 [ 1474 ] {498ab061-b17a-4a3b-b500-4ca09c165284} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000042 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:12.431593 [ 1474 ] {498ab061-b17a-4a3b-b500-4ca09c165284} DDLWorker: Query /* ddl_entry=query-0000000042 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:12.481373 [ 22858 ] {41e88cfe-1d19-4e73-985b-d97e9d475407} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:57312) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:12.481770 [ 22858 ] {41e88cfe-1d19-4e73-985b-d97e9d475407} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:13.047016 [ 1474 ] {37cc60fb-5409-421d-81eb-b31829ce8b56} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000044 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:13.047319 [ 1474 ] {37cc60fb-5409-421d-81eb-b31829ce8b56} DDLWorker: Query /* ddl_entry=query-0000000044 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:13.100008 [ 48624 ] {1ca92c2d-1d2b-4a56-9190-923196fc29de} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:57542) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:13.100247 [ 48624 ] {1ca92c2d-1d2b-4a56-9190-923196fc29de} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:13.349213 [ 1474 ] {4996e966-77c5-49a4-a9e9-77624ec4fec0} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000045 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:13.349375 [ 1474 ] {4996e966-77c5-49a4-a9e9-77624ec4fec0} DDLWorker: Query /* ddl_entry=query-0000000045 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:13.399961 [ 23606 ] {e618cc17-2e80-4710-9047-981eead8e7d8} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:57658) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:13.400222 [ 23606 ] {e618cc17-2e80-4710-9047-981eead8e7d8} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:13.933996 [ 1474 ] {2099c907-39bc-4720-a0ac-b1e1c8de74ce} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000047 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:13.934165 [ 1474 ] {2099c907-39bc-4720-a0ac-b1e1c8de74ce} DDLWorker: Query /* ddl_entry=query-0000000047 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:13.984497 [ 22863 ] {8c8341eb-9578-40bf-aeff-b3213709288f} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:57848) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:13.984853 [ 22863 ] {8c8341eb-9578-40bf-aeff-b3213709288f} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:14.266222 [ 22866 ] {0e4d7eb3-c6ab-4dde-a570-85ded15296f9} executeQuery: Code: 43. DB::Exception: Expected tuples of the same size as arguments of function tupleHammingDistance. Got Tuple(UInt8) and Tuple(UInt8, UInt8): In scope SELECT tupleHammingDistance(tuple(1), (1, 1)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:57928) (comment: 01653_tuple_hamming_distance_2.sql) (in query: SELECT tupleHammingDistance(tuple(1), tuple(1, 1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionTupleHammingDistance::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021c6835e 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:14.266606 [ 22866 ] {0e4d7eb3-c6ab-4dde-a570-85ded15296f9} TCPHandler: Code: 43. DB::Exception: Expected tuples of the same size as arguments of function tupleHammingDistance. Got Tuple(UInt8) and Tuple(UInt8, UInt8): In scope SELECT tupleHammingDistance(tuple(1), (1, 1)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionTupleHammingDistance::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021c6835e 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:14.297391 [ 1474 ] {c41e67f4-b430-4993-9431-059310289d8e} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000048 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:14.297391 [ 22866 ] {1925dfcc-8122-436f-9533-559e3e948b78} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt8, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT tupleHammingDistance(tuple(1), tuple('a')). (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:57928) (comment: 01653_tuple_hamming_distance_2.sql) (in query: SELECT tupleHammingDistance(tuple(1), tuple('a'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x00000000201a06ea 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002017f1b1 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 13. DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021c64472 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 15. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 18. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 20. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 22. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 25. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:14:14.297627 [ 1474 ] {c41e67f4-b430-4993-9431-059310289d8e} DDLWorker: Query /* ddl_entry=query-0000000048 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:14.297724 [ 22866 ] {1925dfcc-8122-436f-9533-559e3e948b78} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt8, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT tupleHammingDistance(tuple(1), tuple('a')). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x00000000201a06ea 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002017f1b1 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 13. DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021c64472 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 15. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 18. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 20. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 22. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 25. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:14:14.299910 [ 22866 ] {16acb7a8-ebc4-40b8-b654-ad40cd3cd792} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt8, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT tupleHammingDistance((1, 3), (3, 'a')). (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:57928) (comment: 01653_tuple_hamming_distance_2.sql) (in query: SELECT tupleHammingDistance((1, 3), (3, 'a'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x00000000201a06ea 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002017f1b1 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 13. DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021c64472 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 15. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 18. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 20. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 22. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 25. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:14:14.300030 [ 22866 ] {16acb7a8-ebc4-40b8-b654-ad40cd3cd792} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt8, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT tupleHammingDistance((1, 3), (3, 'a')). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58ef16 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x00000000201a06ea 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002017f1b1 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 13. DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021c64472 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 15. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 18. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 20. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 22. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 25. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:14:14.343843 [ 23621 ] {3180d692-725e-4ac6-b06a-0959cb0266ec} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:57976) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:14.344110 [ 23621 ] {3180d692-725e-4ac6-b06a-0959cb0266ec} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:14.956168 [ 48606 ] {e1605023-6880-4c5e-83f5-46c6018b23a7} executeQuery: Code: 125. DB::Exception: Scalar subquery returned empty result of type Tuple(Array(Nullable(Float64)), String) which cannot be Nullable. (INCORRECT_RESULT_OF_SCALAR_SUBQUERY) (version 24.3.12.76.altinitystable) (from [::1]:58040) (comment: 01651_bugs_from_15889.sql) (in query: WITH concat(addressToLine(arrayJoin(trace) AS addr), '#') AS symbol SELECT count() > 7 FROM trace_log AS t WHERE (query_id = ( SELECT [NULL, NULL, NULL, NULL, 0.00009999999747378752, NULL, NULL, NULL, NULL, NULL], query_id FROM system.query_log WHERE current_database = currentDatabase() AND (query LIKE '%test cpu time query profiler%') AND (query NOT LIKE '%system%') ORDER BY event_time DESC LIMIT 1 )) AND (symbol LIKE '%Source%');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308bf2ee 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882eee 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:14.956507 [ 48606 ] {e1605023-6880-4c5e-83f5-46c6018b23a7} TCPHandler: Code: 125. DB::Exception: Scalar subquery returned empty result of type Tuple(Array(Nullable(Float64)), String) which cannot be Nullable. (INCORRECT_RESULT_OF_SCALAR_SUBQUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308bf2ee 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882eee 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:14.983834 [ 48606 ] {014ef37f-fbfa-4d2e-b2e8-03f1a21c5af7} executeQuery: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope WITH addressToSymbol(arrayJoin(trace)) AS symbol SELECT count() > 0 FROM trace_log AS t WHERE greaterOrEquals(event_date, ignore(ignore(ignore(NULL, '')), 256), yesterday()) AND (trace_type = 'Memory') AND (query_id = (SELECT ignore(ignore(ignore(ignore(65536)), ignore(65537), ignore(2)), ''), query_id FROM system.query_log WHERE (current_database = currentDatabase()) AND (event_date >= yesterday()) AND (query LIKE '%test memory profiler%') ORDER BY event_time DESC LIMIT 1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:58040) (comment: 01651_bugs_from_15889.sql) (in query: WITH addressToSymbol(arrayJoin(trace)) AS symbol SELECT count() > 0 FROM trace_log AS t WHERE greaterOrEquals(event_date, ignore(ignore(ignore(NULL, '')), 256), yesterday()) AND (trace_type = 'Memory') AND (query_id = ( SELECT ignore(ignore(ignore(ignore(65536)), ignore(65537), ignore(2)), ''), query_id FROM system.query_log WHERE current_database = currentDatabase() AND (event_date >= yesterday()) AND (query LIKE '%test memory profiler%') ORDER BY event_time DESC LIMIT 1 ));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:14.984127 [ 48606 ] {014ef37f-fbfa-4d2e-b2e8-03f1a21c5af7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope WITH addressToSymbol(arrayJoin(trace)) AS symbol SELECT count() > 0 FROM trace_log AS t WHERE greaterOrEquals(event_date, ignore(ignore(ignore(NULL, '')), 256), yesterday()) AND (trace_type = 'Memory') AND (query_id = (SELECT ignore(ignore(ignore(ignore(65536)), ignore(65537), ignore(2)), ''), query_id FROM system.query_log WHERE (current_database = currentDatabase()) AND (event_date >= yesterday()) AND (query LIKE '%test memory profiler%') ORDER BY event_time DESC LIMIT 1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:15.130381 [ 48606 ] {1ac18142-8d46-4518-97e9-00045ceae210} executeQuery: Code: 43. DB::Exception: Illegal type Tuple(inf Float64, query_start_time DateTime) of argument of function toDateTime: In scope WITH ((SELECT query_start_time_microseconds FROM system.query_log WHERE current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1) AS time_with_microseconds, (SELECT inf, query_start_time FROM system.query_log WHERE current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1) AS t) SELECT if(dateDiff('second', toDateTime(time_with_microseconds), toDateTime(t)) = -9223372036854775808, 'ok', ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58040) (comment: 01651_bugs_from_15889.sql) (in query: WITH ( ( SELECT query_start_time_microseconds FROM system.query_log WHERE current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1 ) AS time_with_microseconds, ( SELECT inf, query_start_time FROM system.query_log WHERE current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1 ) AS t) SELECT if(dateDiff('second', toDateTime(time_with_microseconds), toDateTime(t)) = -9223372036854775808, 'ok', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018496b6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 19. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a6916 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 24. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 30. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 2025.03.05 21:14:15.131134 [ 48606 ] {1ac18142-8d46-4518-97e9-00045ceae210} TCPHandler: Code: 43. DB::Exception: Illegal type Tuple(inf Float64, query_start_time DateTime) of argument of function toDateTime: In scope WITH ((SELECT query_start_time_microseconds FROM system.query_log WHERE current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1) AS time_with_microseconds, (SELECT inf, query_start_time FROM system.query_log WHERE current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1) AS t) SELECT if(dateDiff('second', toDateTime(time_with_microseconds), toDateTime(t)) = -9223372036854775808, 'ok', ''). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018496b6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 19. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a6916 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 24. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 30. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 2025.03.05 21:14:15.188485 [ 1474 ] {bdcc41d3-0a80-4bbd-b810-e8c7ea03d6ec} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000051 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:15.188688 [ 1474 ] {bdcc41d3-0a80-4bbd-b810-e8c7ea03d6ec} DDLWorker: Query /* ddl_entry=query-0000000051 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:15.238216 [ 5753 ] {cc37a6ee-9181-421a-a3f8-55dca067436b} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:58224) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:15.238573 [ 5753 ] {cc37a6ee-9181-421a-a3f8-55dca067436b} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:15.796725 [ 1474 ] {2c28c6b9-61df-40fe-a28f-bd9b48c308e5} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000053 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:15.796878 [ 1474 ] {2c28c6b9-61df-40fe-a28f-bd9b48c308e5} DDLWorker: Query /* ddl_entry=query-0000000053 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:15.847476 [ 48605 ] {0522bea7-208b-4f16-b18f-18f923277755} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:58402) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:15.847771 [ 48605 ] {0522bea7-208b-4f16-b18f-18f923277755} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:16.073546 [ 3522 ] {1ef5f514-3235-4c9b-81c6-60d3a9be5d28} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 19.81 MiB (attempt to allocate chunk of 1302990 bytes), maximum: 19.07 MiB.: While executing MergeSortingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:58466) (comment: 01655_plan_optimizations_optimize_read_in_window_order_long.sh) (in query: select n, sum(x) OVER (ORDER BY n, x ROWS BETWEEN 100 PRECEDING AND CURRENT ROW) from test_01655_plan_optimizations_optimize_read_in_window_order_long_n SETTINGS optimize_read_in_order=0, optimize_read_in_window_order=0, max_memory_usage=20000000, max_threads=1 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x0000000024701dfb 9. ./src/IO/BufferWithOwnMemory.h:0: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x000000002473a644 10. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:67: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long) @ 0x000000002f380737 11. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:169: DB::TemporaryFileStream::OutputWriter::OutputWriter(std::unique_ptr>, DB::Block const&, DB::TemporaryDataOnDiskSettings const&) @ 0x000000003157e12a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::TemporaryFileStream::TemporaryFileStream(std::unique_ptr>, DB::Block const&, DB::TemporaryDataOnDisk*) @ 0x00000000315799ec 13. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:94: DB::TemporaryDataOnDisk::createStream(DB::Block const&, unsigned long) @ 0x0000000031579463 14. ./build_docker/./src/Processors/Transforms/MergeSortingTransform.cpp:0: DB::MergeSortingTransform::consume(DB::Chunk) @ 0x0000000033b8e679 15. ./build_docker/./src/Processors/Transforms/SortingTransform.cpp:0: DB::SortingTransform::work() @ 0x0000000033bb7503 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:16.074393 [ 3522 ] {1ef5f514-3235-4c9b-81c6-60d3a9be5d28} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 19.81 MiB (attempt to allocate chunk of 1302990 bytes), maximum: 19.07 MiB.: While executing MergeSortingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x0000000024701dfb 9. ./src/IO/BufferWithOwnMemory.h:0: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x000000002473a644 10. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:67: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long) @ 0x000000002f380737 11. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:169: DB::TemporaryFileStream::OutputWriter::OutputWriter(std::unique_ptr>, DB::Block const&, DB::TemporaryDataOnDiskSettings const&) @ 0x000000003157e12a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::TemporaryFileStream::TemporaryFileStream(std::unique_ptr>, DB::Block const&, DB::TemporaryDataOnDisk*) @ 0x00000000315799ec 13. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:94: DB::TemporaryDataOnDisk::createStream(DB::Block const&, unsigned long) @ 0x0000000031579463 14. ./build_docker/./src/Processors/Transforms/MergeSortingTransform.cpp:0: DB::MergeSortingTransform::consume(DB::Chunk) @ 0x0000000033b8e679 15. ./build_docker/./src/Processors/Transforms/SortingTransform.cpp:0: DB::SortingTransform::work() @ 0x0000000033bb7503 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:16.074919 [ 1474 ] {58eb98a0-9354-4066-aa78-4521341be4ea} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000054 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:16.075074 [ 1474 ] {58eb98a0-9354-4066-aa78-4521341be4ea} DDLWorker: Query /* ddl_entry=query-0000000054 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:16.123846 [ 23622 ] {ba04aa99-4f72-4e49-b33e-820a7a73db16} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:58536) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:16.124051 [ 23622 ] {ba04aa99-4f72-4e49-b33e-820a7a73db16} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:16.359215 [ 48626 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::1]:58588). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:16.669052 [ 1474 ] {4af03ae9-3ed1-4964-be02-b0653062d23b} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000056 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:16.669330 [ 1474 ] {4af03ae9-3ed1-4964-be02-b0653062d23b} DDLWorker: Query /* ddl_entry=query-0000000056 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:16.718333 [ 23498 ] {400fea19-870c-4ca7-9909-1a09d5b1be80} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:58674) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:16.718664 [ 23498 ] {400fea19-870c-4ca7-9909-1a09d5b1be80} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:17.223291 [ 1474 ] {470f2b7c-db3e-41da-9ebf-e2ab77bb1e9b} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000058 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:17.223504 [ 1474 ] {470f2b7c-db3e-41da-9ebf-e2ab77bb1e9b} DDLWorker: Query /* ddl_entry=query-0000000058 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:17.245542 [ 23590 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:48718). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:17.289167 [ 48626 ] {680c6638-6942-4dc3-813c-592c9835a084} executeQuery: Code: 306. DB::Exception: Maximum parse depth (150) exceeded. Consider rising max_parser_depth parameter.: while receiving packet from 127.0.0.1:9000: While executing Remote. (TOO_DEEP_RECURSION) (version 24.3.12.76.altinitystable) (from [::1]:58794) (comment: 01675_data_type_coroutine.sh) (in query: SELECT * FROM remote('127.0.0.{1,2}', generateRandom('x Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(UInt8)))))))))))))))))))))))))))))))))))))))))))))))))', 1, 1, 1)) LIMIT 1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x000000002e97541a 4. ./src/Parsers/IParserBase.h:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462545e 5. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034669950 6. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 7. ./src/Parsers/ParserCreateQuery.h:69: DB::IParserNameTypePair::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346656bf 8. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 9. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 10. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 11. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 12. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserNameTypePairList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034642dfc 13. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 14. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:72: DB::ParserNestedTable::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034641c3d 15. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 16. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034669950 17. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 18. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::(anonymous namespace)::ParserDataTypeArgument::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466b941 19. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 20. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 21. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 22. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 23. ./build_docker/./src/Parsers/ParserDataType.cpp:146: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466a9af 24. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 25. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::(anonymous namespace)::ParserDataTypeArgument::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466b941 26. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 27. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 28. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 29. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 30. ./build_docker/./src/Parsers/ParserDataType.cpp:146: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466a9af 31. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 2025.03.05 21:14:17.289202 [ 10241 ] {1748227b-7d0c-438d-9e0d-266725489ac0} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:58814) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:17.289622 [ 10241 ] {1748227b-7d0c-438d-9e0d-266725489ac0} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:17.289647 [ 48626 ] {680c6638-6942-4dc3-813c-592c9835a084} TCPHandler: Code: 306. DB::Exception: Maximum parse depth (150) exceeded. Consider rising max_parser_depth parameter.: while receiving packet from 127.0.0.1:9000: While executing Remote. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x000000002e97541a 4. ./src/Parsers/IParserBase.h:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462545e 5. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034669950 6. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 7. ./src/Parsers/ParserCreateQuery.h:69: DB::IParserNameTypePair::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346656bf 8. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 9. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 10. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 11. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 12. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserNameTypePairList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034642dfc 13. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 14. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:72: DB::ParserNestedTable::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034641c3d 15. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 16. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034669950 17. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 18. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::(anonymous namespace)::ParserDataTypeArgument::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466b941 19. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 20. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 21. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 22. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 23. ./build_docker/./src/Parsers/ParserDataType.cpp:146: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466a9af 24. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 25. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::(anonymous namespace)::ParserDataTypeArgument::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466b941 26. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 27. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 28. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 29. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 30. ./build_docker/./src/Parsers/ParserDataType.cpp:146: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466a9af 31. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 2025.03.05 21:14:17.289831 [ 48626 ] {680c6638-6942-4dc3-813c-592c9835a084} TCPHandler: Client has gone away. 2025.03.05 21:14:17.474064 [ 23590 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:48736). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:17.476014 [ 12525 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:43874). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:17.476087 [ 10241 ] {ca8520b4-021b-4272-8f22-ae49f410bd2a} executeQuery: Code: 306. DB::Exception: Maximum parse depth (150) exceeded. Consider rising max_parser_depth parameter.: while receiving packet from 127.0.0.1:9000: While executing Remote. (TOO_DEEP_RECURSION) (version 24.3.12.76.altinitystable) (from [::1]:58868) (comment: 01675_data_type_coroutine_2.sh) (in query: SELECT * FROM remote('127.0.0.{1,2}', generateRandom('x Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(UInt8)))))))))))))))))))))))))))))))))))))))))))))))))', 1, 1, 1)) LIMIT 1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x000000002e97541a 4. ./src/Parsers/IParserBase.h:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462545e 5. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034669950 6. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 7. ./src/Parsers/ParserCreateQuery.h:69: DB::IParserNameTypePair::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346656bf 8. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 9. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 10. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 11. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 12. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserNameTypePairList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034642dfc 13. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 14. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:72: DB::ParserNestedTable::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034641c3d 15. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 16. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034669950 17. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 18. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::(anonymous namespace)::ParserDataTypeArgument::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466b941 19. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 20. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 21. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 22. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 23. ./build_docker/./src/Parsers/ParserDataType.cpp:146: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466a9af 24. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 25. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::(anonymous namespace)::ParserDataTypeArgument::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466b941 26. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 27. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 28. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 29. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 30. ./build_docker/./src/Parsers/ParserDataType.cpp:146: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466a9af 31. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 2025.03.05 21:14:17.476537 [ 10241 ] {ca8520b4-021b-4272-8f22-ae49f410bd2a} TCPHandler: Code: 306. DB::Exception: Maximum parse depth (150) exceeded. Consider rising max_parser_depth parameter.: while receiving packet from 127.0.0.1:9000: While executing Remote. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x000000002e97541a 4. ./src/Parsers/IParserBase.h:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462545e 5. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034669950 6. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 7. ./src/Parsers/ParserCreateQuery.h:69: DB::IParserNameTypePair::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346656bf 8. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 9. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 10. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 11. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 12. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:0: DB::ParserNameTypePairList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034642dfc 13. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 14. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:72: DB::ParserNestedTable::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034641c3d 15. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 16. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000034669950 17. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 18. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::(anonymous namespace)::ParserDataTypeArgument::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466b941 19. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 20. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 21. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 22. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 23. ./build_docker/./src/Parsers/ParserDataType.cpp:146: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466a9af 24. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 25. ./build_docker/./src/Parsers/ParserDataType.cpp:0: DB::(anonymous namespace)::ParserDataTypeArgument::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466b941 26. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 27. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 28. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 29. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 30. ./build_docker/./src/Parsers/ParserDataType.cpp:146: DB::ParserDataType::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003466a9af 31. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 2025.03.05 21:14:17.477058 [ 10241 ] {ca8520b4-021b-4272-8f22-ae49f410bd2a} TCPHandler: Client has gone away. 2025.03.05 21:14:17.509560 [ 1474 ] {e47ef287-cdb2-4430-9eec-9e10f8d2188d} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000059 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:17.509843 [ 1474 ] {e47ef287-cdb2-4430-9eec-9e10f8d2188d} DDLWorker: Query /* ddl_entry=query-0000000059 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:17.558433 [ 23590 ] {9bff0bf5-a6f6-4dd2-8249-09b495c4d937} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:58894) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:17.558721 [ 23590 ] {9bff0bf5-a6f6-4dd2-8249-09b495c4d937} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:18.117699 [ 48631 ] {781c22d7-e9b9-4735-a8e6-7ba82770a84f} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58994) (comment: 01635_sum_map_fuzz.sql) (in query: SELECT [NULL], sumMapWithOverflow(events, [NULL], [[(NULL)]], counts) FROM sum_map_overflow;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:0: DB::registerAggregateFunctionSumMap(DB::AggregateFunctionFactory&)::$_3::operator()(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) const @ 0x000000002757963e 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:18.118394 [ 48631 ] {781c22d7-e9b9-4735-a8e6-7ba82770a84f} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:0: DB::registerAggregateFunctionSumMap(DB::AggregateFunctionFactory&)::$_3::operator()(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) const @ 0x000000002757963e 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:18.177461 [ 48631 ] {f10781cd-3d9b-4623-b0b8-c33826018e46} executeQuery: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUUID(-1.1). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:59016) (comment: 01634_uuid_fuzz.sql) (in query: SELECT toUUID(-1.1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001850083d 5. DB::(anonymous namespace)::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000184f83ef 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:18.177712 [ 48631 ] {f10781cd-3d9b-4623-b0b8-c33826018e46} TCPHandler: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUUID(-1.1). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001850083d 5. DB::(anonymous namespace)::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000184f83ef 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:18.329843 [ 48631 ] {ce8980f5-5d24-4914-8c72-508895795f6f} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(groupArray(9223372036854775807), UInt32) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: groupArray instead of groupArray. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:59046) (comment: 01632_group_array_msan.sql) (in query: SELECT groupArrayMerge(1048577)(y * 1048576) FROM (SELECT groupArrayState(9223372036854775807)(x) AS y FROM (SELECT 1048576 AS x)) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028f70b49 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:18.330078 [ 48631 ] {ce8980f5-5d24-4914-8c72-508895795f6f} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(groupArray(9223372036854775807), UInt32) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: groupArray instead of groupArray. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028f70b49 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:18.393240 [ 48581 ] {a1f820e3-96cd-4ed8-9dff-1e5ee9c3d3f4} executeQuery: Code: 36. DB::Exception: Floating point partition key is not supported: a. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:59074) (comment: 01630_disallow_floating_point_as_partition_key.sql) (in query: CREATE TABLE test (`a` Float32, `b` int) ENGINE = MergeTree PARTITION BY a ORDER BY tuple() SETTINGS index_granularity = 3817, min_bytes_for_wide_part = 41965180, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 66, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 137957858, compact_parts_max_granules_to_buffer = 81, compact_parts_merge_max_bytes_to_prefetch_part = 31581055, merge_max_block_size = 9572, old_parts_lifetime = 66., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10426048439, index_granularity_bytes = 15767248, concurrent_part_removal_threshold = 9, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 97951, primary_key_compress_block_size = 85043), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:713: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306e258 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:18.393266 [ 48631 ] {e03fc3e1-ff91-4dd7-b8f6-e6d2886168db} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(quantileResample(0.1, 1, 2, 42), UInt64, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: quantileResample instead of quantileResample. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:59046) (comment: 01632_group_array_msan.sql) (in query: SELECT quantileResampleMerge(0.5, 257, 65536, 1)(tuple(*).1) FROM (SELECT quantileResampleState(0.10, 1, 2, 42)(number, number) FROM numbers(100));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028f70b49 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:18.393442 [ 48581 ] {a1f820e3-96cd-4ed8-9dff-1e5ee9c3d3f4} TCPHandler: Code: 36. DB::Exception: Floating point partition key is not supported: a. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:713: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306e258 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:18.393511 [ 48631 ] {e03fc3e1-ff91-4dd7-b8f6-e6d2886168db} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(quantileResample(0.1, 1, 2, 42), UInt64, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: quantileResample instead of quantileResample. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:0: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028f70b49 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:18.409367 [ 48581 ] {ab679f82-4a13-4af5-abb5-6acda9a38825} executeQuery: Code: 36. DB::Exception: Floating point partition key is not supported: d. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:59074) (comment: 01630_disallow_floating_point_as_partition_key.sql) (in query: CREATE TABLE test (`a` Float32, `b` int, `c` String, `d` Float64) ENGINE = MergeTree PARTITION BY (b, c, d) ORDER BY tuple() SETTINGS allow_floating_point_partition_key = false, index_granularity = 3817, min_bytes_for_wide_part = 41965180, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 66, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 137957858, compact_parts_max_granules_to_buffer = 81, compact_parts_merge_max_bytes_to_prefetch_part = 31581055, merge_max_block_size = 9572, old_parts_lifetime = 66., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10426048439, index_granularity_bytes = 15767248, concurrent_part_removal_threshold = 9, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 97951, primary_key_compress_block_size = 85043), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:713: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306e258 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:18.409544 [ 48581 ] {ab679f82-4a13-4af5-abb5-6acda9a38825} TCPHandler: Code: 36. DB::Exception: Floating point partition key is not supported: d. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:713: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306e258 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:18.440830 [ 1474 ] {5bb97729-3a13-418d-9b0c-35f41240aa0f} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000062 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:18.441039 [ 1474 ] {5bb97729-3a13-418d-9b0c-35f41240aa0f} DDLWorker: Query /* ddl_entry=query-0000000062 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:18.490424 [ 12525 ] {3e3ef8a6-cf2a-4a11-af2b-9db56228baed} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:59080) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:18.490745 [ 12525 ] {3e3ef8a6-cf2a-4a11-af2b-9db56228baed} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:19.374992 [ 1474 ] {e88908fe-ca31-40f5-9445-0dfc299bbcd6} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01671_ddl_hang_timeout_long_test_mihxuc37/test_01671/replicas/r_6). (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000065 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000324a2912 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795294 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 15. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:19.375206 [ 1474 ] {e88908fe-ca31-40f5-9445-0dfc299bbcd6} DDLWorker: Query /* ddl_entry=query-0000000065 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01671_ddl_hang_timeout_long_test_mihxuc37/test_01671/replicas/r_6). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000324a2912 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795294 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 15. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:19.405814 [ 23597 ] {b73df41e-a5fe-4644-b53e-711c32f36896} executeQuery: Code: 242. DB::Exception: There was an error on [localhost:9000]: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01671_ddl_hang_timeout_long_test_mihxuc37/test_01671/replicas/r_6). (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable). (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:45828) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:19.406187 [ 23597 ] {b73df41e-a5fe-4644-b53e-711c32f36896} TCPHandler: Code: 242. DB::Exception: There was an error on [localhost:9000]: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01671_ddl_hang_timeout_long_test_mihxuc37/test_01671/replicas/r_6). (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:19.421664 [ 48631 ] {c65fe83f-a204-423d-9b25-cf032026f988} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 19.81 MiB (attempt to allocate chunk of 1303022 bytes), maximum: 19.07 MiB.: While executing MergeSortingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:45818) (comment: 01655_plan_optimizations_optimize_read_in_window_order_long.sh) (in query: select n, sum(x) OVER (ORDER BY n, x ROWS BETWEEN 100 PRECEDING AND CURRENT ROW) from test_01655_plan_optimizations_optimize_read_in_window_order_long_n_x SETTINGS optimize_read_in_order=0, optimize_read_in_window_order=0, max_memory_usage=20000000, max_threads=1 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x0000000024701dfb 9. ./src/IO/BufferWithOwnMemory.h:0: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x000000002473a644 10. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:67: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long) @ 0x000000002f380737 11. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:169: DB::TemporaryFileStream::OutputWriter::OutputWriter(std::unique_ptr>, DB::Block const&, DB::TemporaryDataOnDiskSettings const&) @ 0x000000003157e12a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::TemporaryFileStream::TemporaryFileStream(std::unique_ptr>, DB::Block const&, DB::TemporaryDataOnDisk*) @ 0x00000000315799ec 13. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:94: DB::TemporaryDataOnDisk::createStream(DB::Block const&, unsigned long) @ 0x0000000031579463 14. ./build_docker/./src/Processors/Transforms/MergeSortingTransform.cpp:0: DB::MergeSortingTransform::consume(DB::Chunk) @ 0x0000000033b8e679 15. ./build_docker/./src/Processors/Transforms/SortingTransform.cpp:0: DB::SortingTransform::work() @ 0x0000000033bb7503 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:19.422658 [ 48631 ] {c65fe83f-a204-423d-9b25-cf032026f988} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 19.81 MiB (attempt to allocate chunk of 1303022 bytes), maximum: 19.07 MiB.: While executing MergeSortingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x0000000024701dfb 9. ./src/IO/BufferWithOwnMemory.h:0: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x000000002473a644 10. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:67: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long) @ 0x000000002f380737 11. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:169: DB::TemporaryFileStream::OutputWriter::OutputWriter(std::unique_ptr>, DB::Block const&, DB::TemporaryDataOnDiskSettings const&) @ 0x000000003157e12a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::TemporaryFileStream::TemporaryFileStream(std::unique_ptr>, DB::Block const&, DB::TemporaryDataOnDisk*) @ 0x00000000315799ec 13. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:94: DB::TemporaryDataOnDisk::createStream(DB::Block const&, unsigned long) @ 0x0000000031579463 14. ./build_docker/./src/Processors/Transforms/MergeSortingTransform.cpp:0: DB::MergeSortingTransform::consume(DB::Chunk) @ 0x0000000033b8e679 15. ./build_docker/./src/Processors/Transforms/SortingTransform.cpp:0: DB::SortingTransform::work() @ 0x0000000033bb7503 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:19.743788 [ 1474 ] {02858cfe-d6e7-4aac-b960-50591f934b49} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000066 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:19.743927 [ 1474 ] {02858cfe-d6e7-4aac-b960-50591f934b49} DDLWorker: Query /* ddl_entry=query-0000000066 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:19.794825 [ 48581 ] {61d63c13-66dc-4858-ac42-3257742f8485} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:45852) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:19.795105 [ 48581 ] {61d63c13-66dc-4858-ac42-3257742f8485} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:20.725135 [ 1474 ] {} DDLWorker: , task query-0000000067 will not be executed. 2025.03.05 21:14:20.816258 [ 23611 ] {e79a47e9-d353-478f-b32c-4f0eb18f3032} executeQuery: Code: 341. DB::Exception: There was an error on [localhost:9000]: Cannot execute replicated DDL query, table is dropped or detached permanently. (UNFINISHED) (version 24.3.12.76.altinitystable) (from [::1]:45868) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:20.816513 [ 23611 ] {e79a47e9-d353-478f-b32c-4f0eb18f3032} TCPHandler: Code: 341. DB::Exception: There was an error on [localhost:9000]: Cannot execute replicated DDL query, table is dropped or detached permanently. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:21.544268 [ 1474 ] {4ea48cf9-0e4f-432a-8c75-4ebe07ee19c0} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000069 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:21.544799 [ 1474 ] {4ea48cf9-0e4f-432a-8c75-4ebe07ee19c0} DDLWorker: Query /* ddl_entry=query-0000000069 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:21.613613 [ 22858 ] {ee77e42c-2446-4aea-a892-79fa7597ff26} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:45982) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:21.613863 [ 22858 ] {ee77e42c-2446-4aea-a892-79fa7597ff26} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:21.907060 [ 1474 ] {dd630053-fb2f-4132-b9f7-2569b8b3ce7d} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000070 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:21.907232 [ 1474 ] {dd630053-fb2f-4132-b9f7-2569b8b3ce7d} DDLWorker: Query /* ddl_entry=query-0000000070 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:21.956784 [ 23586 ] {5457a8ab-9331-4f9a-8d70-1d67955c1600} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:46038) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:21.957021 [ 23586 ] {5457a8ab-9331-4f9a-8d70-1d67955c1600} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:22.193234 [ 1474 ] {17886abd-9de4-4121-9468-9b6f6b8127cf} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000071 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:22.200942 [ 1474 ] {17886abd-9de4-4121-9468-9b6f6b8127cf} DDLWorker: Query /* ddl_entry=query-0000000071 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:22.237755 [ 23611 ] {6e59ea45-9e20-4703-bd62-e783653eea80} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:46080) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:22.238013 [ 23611 ] {6e59ea45-9e20-4703-bd62-e783653eea80} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:22.502149 [ 23586 ] {d964c6d2-e162-440d-bda0-436eaf95d76b} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 19.81 MiB (attempt to allocate chunk of 1303022 bytes), maximum: 19.07 MiB.: While executing MergeSortingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:46134) (comment: 01655_plan_optimizations_optimize_read_in_window_order_long.sh) (in query: select n, sum(x) OVER (PARTITION BY n ORDER BY x ROWS BETWEEN 100 PRECEDING AND CURRENT ROW) from test_01655_plan_optimizations_optimize_read_in_window_order_long_n_x SETTINGS optimize_read_in_order=0, optimize_read_in_window_order=0, max_memory_usage=20000000, max_threads=1 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x0000000024701dfb 9. ./src/IO/BufferWithOwnMemory.h:0: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x000000002473a644 10. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:67: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long) @ 0x000000002f380737 11. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:169: DB::TemporaryFileStream::OutputWriter::OutputWriter(std::unique_ptr>, DB::Block const&, DB::TemporaryDataOnDiskSettings const&) @ 0x000000003157e12a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::TemporaryFileStream::TemporaryFileStream(std::unique_ptr>, DB::Block const&, DB::TemporaryDataOnDisk*) @ 0x00000000315799ec 13. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:94: DB::TemporaryDataOnDisk::createStream(DB::Block const&, unsigned long) @ 0x0000000031579463 14. ./build_docker/./src/Processors/Transforms/MergeSortingTransform.cpp:0: DB::MergeSortingTransform::consume(DB::Chunk) @ 0x0000000033b8e679 15. ./build_docker/./src/Processors/Transforms/SortingTransform.cpp:0: DB::SortingTransform::work() @ 0x0000000033bb7503 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:22.502728 [ 23586 ] {d964c6d2-e162-440d-bda0-436eaf95d76b} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 19.81 MiB (attempt to allocate chunk of 1303022 bytes), maximum: 19.07 MiB.: While executing MergeSortingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x0000000024701dfb 9. ./src/IO/BufferWithOwnMemory.h:0: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x000000002473a644 10. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:67: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long) @ 0x000000002f380737 11. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:169: DB::TemporaryFileStream::OutputWriter::OutputWriter(std::unique_ptr>, DB::Block const&, DB::TemporaryDataOnDiskSettings const&) @ 0x000000003157e12a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::TemporaryFileStream::TemporaryFileStream(std::unique_ptr>, DB::Block const&, DB::TemporaryDataOnDisk*) @ 0x00000000315799ec 13. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:94: DB::TemporaryDataOnDisk::createStream(DB::Block const&, unsigned long) @ 0x0000000031579463 14. ./build_docker/./src/Processors/Transforms/MergeSortingTransform.cpp:0: DB::MergeSortingTransform::consume(DB::Chunk) @ 0x0000000033b8e679 15. ./build_docker/./src/Processors/Transforms/SortingTransform.cpp:0: DB::SortingTransform::work() @ 0x0000000033bb7503 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:22.740633 [ 1474 ] {31c58bad-7508-4677-87b0-2e30dd54d0e1} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000073 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:22.740882 [ 1474 ] {31c58bad-7508-4677-87b0-2e30dd54d0e1} DDLWorker: Query /* ddl_entry=query-0000000073 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:22.790820 [ 23587 ] {334d6acd-c55b-444b-9d7b-3f6b3cd4790b} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:46168) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:22.791047 [ 23587 ] {334d6acd-c55b-444b-9d7b-3f6b3cd4790b} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:23.340874 [ 1474 ] {ea6868dd-825e-42aa-86d0-488ebb4cc819} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000075 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:23.341069 [ 1474 ] {ea6868dd-825e-42aa-86d0-488ebb4cc819} DDLWorker: Query /* ddl_entry=query-0000000075 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:23.391465 [ 14920 ] {a726db3a-cd05-48ba-bfa0-26537d9cbb88} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:46242) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:23.391795 [ 14920 ] {a726db3a-cd05-48ba-bfa0-26537d9cbb88} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:23.890588 [ 1474 ] {35b3328d-d692-45ea-b209-9829464ebe29} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000077 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:23.890840 [ 1474 ] {35b3328d-d692-45ea-b209-9829464ebe29} DDLWorker: Query /* ddl_entry=query-0000000077 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:23.940323 [ 23606 ] {500c9265-263e-4d30-98fa-dc525c141aa5} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:46312) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:23.940580 [ 23606 ] {500c9265-263e-4d30-98fa-dc525c141aa5} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:24.263562 [ 1474 ] {fef4b71c-200b-45f2-86df-f3e1fd9c4902} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000078 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:24.263736 [ 1474 ] {fef4b71c-200b-45f2-86df-f3e1fd9c4902} DDLWorker: Query /* ddl_entry=query-0000000078 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:24.313730 [ 14920 ] {90b09997-008c-4743-b305-a5a974f3b431} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:46370) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:24.313953 [ 14920 ] {90b09997-008c-4743-b305-a5a974f3b431} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:24.818661 [ 1474 ] {1a038681-f7aa-4167-994f-c350d4b54b80} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000080 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:24.818842 [ 1474 ] {1a038681-f7aa-4167-994f-c350d4b54b80} DDLWorker: Query /* ddl_entry=query-0000000080 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:24.868995 [ 48603 ] {7a95ab4a-71f2-42cd-a152-7f7391ed7938} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:46456) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:24.869249 [ 48603 ] {7a95ab4a-71f2-42cd-a152-7f7391ed7938} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:25.230983 [ 48598 ] {7f30c904-44ec-4cef-9b0a-2289c4d52ede} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 19.23 MiB (attempt to allocate chunk of 1321518 bytes), maximum: 19.07 MiB.: While executing MergeSortingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:46540) (comment: 01655_plan_optimizations_optimize_read_in_window_order_long.sh) (in query: select n, sum(x) OVER (PARTITION BY n+x%2 ORDER BY n, x ROWS BETWEEN 100 PRECEDING AND CURRENT ROW) from test_01655_plan_optimizations_optimize_read_in_window_order_long_n_x SETTINGS optimize_read_in_order=1, max_memory_usage=20000000, max_threads=1 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x0000000024701dfb 9. ./src/IO/BufferWithOwnMemory.h:0: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x000000002473a644 10. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:67: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long) @ 0x000000002f380737 11. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:169: DB::TemporaryFileStream::OutputWriter::OutputWriter(std::unique_ptr>, DB::Block const&, DB::TemporaryDataOnDiskSettings const&) @ 0x000000003157e12a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::TemporaryFileStream::TemporaryFileStream(std::unique_ptr>, DB::Block const&, DB::TemporaryDataOnDisk*) @ 0x00000000315799ec 13. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:94: DB::TemporaryDataOnDisk::createStream(DB::Block const&, unsigned long) @ 0x0000000031579463 14. ./build_docker/./src/Processors/Transforms/MergeSortingTransform.cpp:0: DB::MergeSortingTransform::consume(DB::Chunk) @ 0x0000000033b8e679 15. ./build_docker/./src/Processors/Transforms/SortingTransform.cpp:0: DB::SortingTransform::work() @ 0x0000000033bb7503 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:25.231695 [ 48598 ] {7f30c904-44ec-4cef-9b0a-2289c4d52ede} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 19.23 MiB (attempt to allocate chunk of 1321518 bytes), maximum: 19.07 MiB.: While executing MergeSortingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x0000000024701dfb 9. ./src/IO/BufferWithOwnMemory.h:0: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x000000002473a644 10. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:67: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long) @ 0x000000002f380737 11. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:169: DB::TemporaryFileStream::OutputWriter::OutputWriter(std::unique_ptr>, DB::Block const&, DB::TemporaryDataOnDiskSettings const&) @ 0x000000003157e12a 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::TemporaryFileStream::TemporaryFileStream(std::unique_ptr>, DB::Block const&, DB::TemporaryDataOnDisk*) @ 0x00000000315799ec 13. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:94: DB::TemporaryDataOnDisk::createStream(DB::Block const&, unsigned long) @ 0x0000000031579463 14. ./build_docker/./src/Processors/Transforms/MergeSortingTransform.cpp:0: DB::MergeSortingTransform::consume(DB::Chunk) @ 0x0000000033b8e679 15. ./build_docker/./src/Processors/Transforms/SortingTransform.cpp:0: DB::SortingTransform::work() @ 0x0000000033bb7503 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:25.407296 [ 1474 ] {1678b799-8eda-4a0f-8acb-324156441c13} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000082 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:25.407485 [ 1474 ] {1678b799-8eda-4a0f-8acb-324156441c13} DDLWorker: Query /* ddl_entry=query-0000000082 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:25.455806 [ 23553 ] {fb0700d3-909a-4891-9f20-367501fc3d28} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:46570) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:25.456083 [ 23553 ] {fb0700d3-909a-4891-9f20-367501fc3d28} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:25.526627 [ 22866 ] {ed0da4d9-04a0-4e31-83e2-90bcde8699c5} executeQuery: Code: 55. DB::Exception: Method write is not supported by storage Distributed with more than one shard and no sharding key provided. (STORAGE_REQUIRES_PARAMETER) (version 24.3.12.76.altinitystable) (from [::1]:46600) (comment: 01602_insert_into_table_function_cluster.sql) (in query: -- More than one shard, sharding key is necessary INSERT INTO FUNCTION cluster('test_cluster_two_shards_localhost', currentDatabase(), x) SELECT * FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000032199d88 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:25.526811 [ 22866 ] {ed0da4d9-04a0-4e31-83e2-90bcde8699c5} TCPHandler: Code: 55. DB::Exception: Method write is not supported by storage Distributed with more than one shard and no sharding key provided. (STORAGE_REQUIRES_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000032199d88 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:25.536828 [ 22866 ] {7c1ed695-70ee-42f6-8160-fd6f724b122e} executeQuery: Code: 55. DB::Exception: Method write is not supported by storage Distributed with more than one shard and no sharding key provided. (STORAGE_REQUIRES_PARAMETER) (version 24.3.12.76.altinitystable) (from [::1]:46600) (comment: 01602_insert_into_table_function_cluster.sql) (in query: INSERT INTO FUNCTION remote('127.0.0.{1,2}', currentDatabase(), y, '[HIDDEN]') SELECT * FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000032199d88 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:25.537038 [ 22866 ] {7c1ed695-70ee-42f6-8160-fd6f724b122e} TCPHandler: Code: 55. DB::Exception: Method write is not supported by storage Distributed with more than one shard and no sharding key provided. (STORAGE_REQUIRES_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000032199d88 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:572: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033ca0e72 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:25.692351 [ 1474 ] {cc09c1bb-b10a-410e-a150-295586e65c61} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000083 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:25.692543 [ 1474 ] {cc09c1bb-b10a-410e-a150-295586e65c61} DDLWorker: Query /* ddl_entry=query-0000000083 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:25.742146 [ 23610 ] {3e75d5ba-5d7b-428a-b77b-c977a5fbe412} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:46630) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:25.742372 [ 23610 ] {3e75d5ba-5d7b-428a-b77b-c977a5fbe412} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:26.055862 [ 23610 ] {f027923e-d0d0-44d4-b55f-410907164eb7} executeQuery: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt8: In scope SELECT accurateCast(-1, 'UInt8'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: SELECT accurateCast(-1, 'UInt8');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000182ab229 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182a411b 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.056057 [ 23610 ] {f027923e-d0d0-44d4-b55f-410907164eb7} TCPHandler: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt8: In scope SELECT accurateCast(-1, 'UInt8'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000182ab229 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182a411b 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.107314 [ 23610 ] {45f6c8da-a779-410e-b372-4408be9436cf} executeQuery: Code: 70. DB::Exception: Value in column UInt16 cannot be safely converted into type UInt8: In scope SELECT accurateCast(257, 'UInt8'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: SELECT accurateCast(257, 'UInt8');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000182ab5ef 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182a411b 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.107530 [ 23610 ] {45f6c8da-a779-410e-b372-4408be9436cf} TCPHandler: Code: 70. DB::Exception: Value in column UInt16 cannot be safely converted into type UInt8: In scope SELECT accurateCast(257, 'UInt8'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000182ab5ef 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182a411b 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.136976 [ 23610 ] {f91e717e-d01f-49b6-997b-42478e822b56} executeQuery: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt16: In scope SELECT accurateCast(-1, 'UInt16'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: SELECT accurateCast(-1, 'UInt16');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000182c32d0 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182bd5fb 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.137213 [ 23610 ] {f91e717e-d01f-49b6-997b-42478e822b56} TCPHandler: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt16: In scope SELECT accurateCast(-1, 'UInt16'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000182c32d0 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182bd5fb 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.172780 [ 23610 ] {73d00525-3fb1-4881-852c-8cc73373a02a} executeQuery: Code: 70. DB::Exception: Value in column UInt32 cannot be safely converted into type UInt16: In scope SELECT accurateCast(65536, 'UInt16'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: SELECT accurateCast(65536, 'UInt16');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000182c3383 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182bd5fb 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.172971 [ 23610 ] {73d00525-3fb1-4881-852c-8cc73373a02a} TCPHandler: Code: 70. DB::Exception: Value in column UInt32 cannot be safely converted into type UInt16: In scope SELECT accurateCast(65536, 'UInt16'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000182c3383 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182bd5fb 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.202351 [ 23610 ] {14041a8c-b122-47d6-903f-59231068478d} executeQuery: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt32: In scope SELECT accurateCast(-1, 'UInt32'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: SELECT accurateCast(-1, 'UInt32');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000182db003 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182d539b 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.202539 [ 23610 ] {14041a8c-b122-47d6-903f-59231068478d} TCPHandler: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt32: In scope SELECT accurateCast(-1, 'UInt32'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000182db003 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182d539b 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.234636 [ 23610 ] {2e3406d0-090c-4dd1-8966-a6ddc2846e63} executeQuery: Code: 70. DB::Exception: Value in column UInt64 cannot be safely converted into type UInt32: In scope SELECT accurateCast(4294967296, 'UInt32'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: SELECT accurateCast(4294967296, 'UInt32');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000182db28d 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182d539b 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.234895 [ 23610 ] {2e3406d0-090c-4dd1-8966-a6ddc2846e63} TCPHandler: Code: 70. DB::Exception: Value in column UInt64 cannot be safely converted into type UInt32: In scope SELECT accurateCast(4294967296, 'UInt32'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000182db28d 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182d539b 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.265409 [ 23610 ] {8d274966-a822-4e8a-8e16-81407038a239} executeQuery: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt64: In scope SELECT accurateCast(-1, 'UInt64'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: SELECT accurateCast(-1, 'UInt64');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000182f2e86 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182ed0fb 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.265675 [ 23610 ] {8d274966-a822-4e8a-8e16-81407038a239} TCPHandler: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt64: In scope SELECT accurateCast(-1, 'UInt64'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000182f2e86 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182ed0fb 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.303526 [ 23610 ] {5cce669e-2a37-40a1-a5bb-2b478469b893} executeQuery: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt256: In scope SELECT accurateCast(-1, 'UInt256'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: SELECT accurateCast(-1, 'UInt256');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType>, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)&&) @ 0x000000001832576f 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001831ef3b 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.303706 [ 23610 ] {5cce669e-2a37-40a1-a5bb-2b478469b893} TCPHandler: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt256: In scope SELECT accurateCast(-1, 'UInt256'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType>, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber> const&)&&) @ 0x000000001832576f 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>>(std::shared_ptr const&, DB::DataTypeNumber> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001831ef3b 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.336174 [ 23610 ] {c76dbf6a-e20e-4e53-be48-fd82f878d4eb} executeQuery: Code: 70. DB::Exception: Value in column Int16 cannot be safely converted into type Int8: In scope SELECT accurateCast(-129, 'Int8'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: SELECT accurateCast(-129, 'Int8');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(DB::ColumnNullable, DB::(anonymous namespace) const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const::'lambda'(DB::(anonymous namespace) const*&)>(DB::TypeIndex, std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(DB::ColumnNullable, DB::(anonymous namespace) const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const::'lambda'(DB::(anonymous namespace) const*&)&&) @ 0x000000001833caa9 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018336afb 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.336512 [ 23610 ] {c76dbf6a-e20e-4e53-be48-fd82f878d4eb} TCPHandler: Code: 70. DB::Exception: Value in column Int16 cannot be safely converted into type Int8: In scope SELECT accurateCast(-129, 'Int8'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(DB::ColumnNullable, DB::(anonymous namespace) const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const::'lambda'(DB::(anonymous namespace) const*&)>(DB::TypeIndex, std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(DB::ColumnNullable, DB::(anonymous namespace) const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const::'lambda'(DB::(anonymous namespace) const*&)&&) @ 0x000000001833caa9 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018336afb 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.367881 [ 23610 ] {9197e7de-66d6-4877-8a43-168ce031fdc6} executeQuery: Code: 70. DB::Exception: Value in column UInt8 cannot be safely converted into type Int8: In scope SELECT accurateCast(128, 'Int8'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: SELECT accurateCast(128, 'Int8');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(DB::ColumnNullable, DB::(anonymous namespace) const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const::'lambda'(DB::(anonymous namespace) const*&)>(DB::TypeIndex, std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(DB::ColumnNullable, DB::(anonymous namespace) const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const::'lambda'(DB::(anonymous namespace) const*&)&&) @ 0x000000001833c77f 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018336afb 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.368105 [ 23610 ] {9197e7de-66d6-4877-8a43-168ce031fdc6} TCPHandler: Code: 70. DB::Exception: Value in column UInt8 cannot be safely converted into type Int8: In scope SELECT accurateCast(128, 'Int8'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(DB::ColumnNullable, DB::(anonymous namespace) const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const::'lambda'(DB::(anonymous namespace) const*&)>(DB::TypeIndex, std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(DB::ColumnNullable, DB::(anonymous namespace) const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const::'lambda'(DB::(anonymous namespace) const*&)&&) @ 0x000000001833c77f 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018336afb 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.396428 [ 23610 ] {1f59fab1-d8d1-4ebd-ae48-167c0645eefc} executeQuery: Code: 407. DB::Exception: Decimal convert overflow: 10000000000 is not in range (-2147483648, 2147483647): In scope SELECT accurateCast(10, 'Decimal32(9)'). (DECIMAL_OVERFLOW) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: SELECT accurateCast(10, 'Decimal32(9)');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:0: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(DB::DataTypeDecimal>::FieldType const&, unsigned int, unsigned int, DB::DataTypeDecimal>::FieldType&) @ 0x000000002f510227 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: DB::DataTypeDecimal>::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(DB::DataTypeNumber::FieldType const&, unsigned int) @ 0x000000002f524fc8 6. bool DB::callOnIndexAndDataType>, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, DB::DataTypeDecimal> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDecimal> const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, DB::DataTypeDecimal> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDecimal> const&)&&) @ 0x00000000183e8de4 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, DB::DataTypeDecimal> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000183e8803 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:26.396666 [ 23610 ] {1f59fab1-d8d1-4ebd-ae48-167c0645eefc} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow: 10000000000 is not in range (-2147483648, 2147483647): In scope SELECT accurateCast(10, 'Decimal32(9)'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:0: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(DB::DataTypeDecimal>::FieldType const&, unsigned int, unsigned int, DB::DataTypeDecimal>::FieldType&) @ 0x000000002f510227 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: DB::DataTypeDecimal>::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(DB::DataTypeNumber::FieldType const&, unsigned int) @ 0x000000002f524fc8 6. bool DB::callOnIndexAndDataType>, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, DB::DataTypeDecimal> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDecimal> const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, DB::DataTypeDecimal> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDecimal> const&)&&) @ 0x00000000183e8de4 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, DB::DataTypeDecimal> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000183e8803 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:26.427074 [ 23610 ] {1820624f-19a4-4ac2-8f71-943decd0a5db} executeQuery: Code: 407. DB::Exception: Decimal convert overflow: -10000000000 is not in range (-2147483648, 2147483647): In scope SELECT accurateCast(-10, 'Decimal32(9)'). (DECIMAL_OVERFLOW) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: SELECT accurateCast(-10, 'Decimal32(9)');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:0: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(DB::DataTypeDecimal>::FieldType const&, unsigned int, unsigned int, DB::DataTypeDecimal>::FieldType&) @ 0x000000002f510227 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: DB::DataTypeDecimal>::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(DB::DataTypeNumber<_BitInt(8)>::FieldType const&, unsigned int) @ 0x000000002f524f89 6. bool DB::callOnIndexAndDataType>, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, DB::DataTypeDecimal> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDecimal> const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, DB::DataTypeDecimal> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDecimal> const&)&&) @ 0x00000000183eb936 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, DB::DataTypeDecimal> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000183e8803 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:26.427291 [ 23610 ] {1820624f-19a4-4ac2-8f71-943decd0a5db} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow: -10000000000 is not in range (-2147483648, 2147483647): In scope SELECT accurateCast(-10, 'Decimal32(9)'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:0: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(DB::DataTypeDecimal>::FieldType const&, unsigned int, unsigned int, DB::DataTypeDecimal>::FieldType&) @ 0x000000002f510227 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:322: DB::DataTypeDecimal>::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(DB::DataTypeNumber<_BitInt(8)>::FieldType const&, unsigned int) @ 0x000000002f524f89 6. bool DB::callOnIndexAndDataType>, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, DB::DataTypeDecimal> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDecimal> const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, DB::DataTypeDecimal> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDecimal> const&)&&) @ 0x00000000183eb936 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, DB::DataTypeDecimal> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000183e8803 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:26.429560 [ 23610 ] {9531f5a3-4901-4db7-bd4d-e96f3f08160e} executeQuery: Code: 131. DB::Exception: String too long for type FixedString(2): In scope SELECT accurateCast('123', 'FixedString(2)'). (TOO_LARGE_STRING_SIZE) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: SELECT accurateCast('123', 'FixedString(2)');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. COW::immutable_ptr DB::FunctionToFixedString::executeForN<(DB::ConvertToFixedStringExceptionMode)0>(std::vector> const&, unsigned long) @ 0x00000000187d8b47 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, unsigned long) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001853a6c4 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.429697 [ 23610 ] {9531f5a3-4901-4db7-bd4d-e96f3f08160e} TCPHandler: Code: 131. DB::Exception: String too long for type FixedString(2): In scope SELECT accurateCast('123', 'FixedString(2)'). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. COW::immutable_ptr DB::FunctionToFixedString::executeForN<(DB::ConvertToFixedStringExceptionMode)0>(std::vector> const&, unsigned long) @ 0x00000000187d8b47 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, unsigned long) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001853a6c4 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.464665 [ 23610 ] {7f7f6484-e94d-407f-8218-29456fd04954} executeQuery: Code: 70. DB::Exception: Value -1 cannot be safely converted into type UInt32: In scope SELECT accurateCast(-1, 'DateTime'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: SELECT accurateCast(-1, 'DateTime');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<_BitInt(8) const&, std::basic_string_view> const&>(int, FormatStringHelperImpl::type, std::basic_string_view::type_identity> const&>::type>, std::basic_string_view::type_identity<_BitInt(8) const&>&&, std::basic_string_view::type_identity> const&>&&) @ 0x00000000187b622a 4. void DB::Transformer, DB::DataTypeDateTime, DB::(anonymous namespace)::ToDateTimeTransformSigned, unsigned int, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false, DB::DateTimeAccurateConvertStrategyAdditions>::vector, 4096ul, Allocator, 63ul, 64ul>, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>&, DateLUTImpl const&, DB::DateTimeAccurateConvertStrategyAdditions const&, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>*) @ 0x00000000184df773 5. COW::immutable_ptr> DB::DateTimeTransformImpl, DB::DataTypeDateTime, DB::(anonymous namespace)::ToDateTimeTransformSigned, unsigned int, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::DateTimeTransformImpl, DB::DataTypeDateTime, DB::(anonymous namespace)::ToDateTimeTransformSigned, unsigned int, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false> const&) @ 0x00000000184defaa 6. bool DB::callOnIndexAndDataType::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDateTime const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDateTime const&)&&) @ 0x00000000184d9781 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000184d1fdb 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:26.464917 [ 23610 ] {7f7f6484-e94d-407f-8218-29456fd04954} TCPHandler: Code: 70. DB::Exception: Value -1 cannot be safely converted into type UInt32: In scope SELECT accurateCast(-1, 'DateTime'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<_BitInt(8) const&, std::basic_string_view> const&>(int, FormatStringHelperImpl::type, std::basic_string_view::type_identity> const&>::type>, std::basic_string_view::type_identity<_BitInt(8) const&>&&, std::basic_string_view::type_identity> const&>&&) @ 0x00000000187b622a 4. void DB::Transformer, DB::DataTypeDateTime, DB::(anonymous namespace)::ToDateTimeTransformSigned, unsigned int, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false, DB::DateTimeAccurateConvertStrategyAdditions>::vector, 4096ul, Allocator, 63ul, 64ul>, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>&, DateLUTImpl const&, DB::DateTimeAccurateConvertStrategyAdditions const&, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>*) @ 0x00000000184df773 5. COW::immutable_ptr> DB::DateTimeTransformImpl, DB::DataTypeDateTime, DB::(anonymous namespace)::ToDateTimeTransformSigned, unsigned int, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::DateTimeTransformImpl, DB::DataTypeDateTime, DB::(anonymous namespace)::ToDateTimeTransformSigned, unsigned int, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false> const&) @ 0x00000000184defaa 6. bool DB::callOnIndexAndDataType::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDateTime const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDateTime const&)&&) @ 0x00000000184d9781 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000184d1fdb 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:26.496563 [ 23610 ] {19a8a9b9-d833-423a-ac71-ec9b6574dbba} executeQuery: Code: 70. DB::Exception: Value 4294967296 cannot be safely converted into type UInt32: In scope SELECT accurateCast(4294967295 + 1, 'DateTime'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: SELECT accurateCast(0xFFFFFFFF + 1, 'DateTime');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, unsigned long const&, std::basic_string_view> const&) @ 0x00000000187b5fa2 4. void DB::Transformer, DB::DataTypeDateTime, DB::(anonymous namespace)::ToDateTimeTransform64, false, DB::DateTimeAccurateConvertStrategyAdditions>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeTransform64 const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000184ddcdf 5. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime, DB::(anonymous namespace)::ToDateTimeTransform64, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeTransform64 const&) @ 0x00000000184dd4ea 6. bool DB::callOnIndexAndDataType::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDateTime const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDateTime const&)&&) @ 0x00000000184d7b01 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000184d1fdb 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:26.496849 [ 23610 ] {19a8a9b9-d833-423a-ac71-ec9b6574dbba} TCPHandler: Code: 70. DB::Exception: Value 4294967296 cannot be safely converted into type UInt32: In scope SELECT accurateCast(4294967295 + 1, 'DateTime'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, unsigned long const&, std::basic_string_view> const&) @ 0x00000000187b5fa2 4. void DB::Transformer, DB::DataTypeDateTime, DB::(anonymous namespace)::ToDateTimeTransform64, false, DB::DateTimeAccurateConvertStrategyAdditions>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTimeTransform64 const&, DB::PODArray, 63ul, 64ul>*) @ 0x00000000184ddcdf 5. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime, DB::(anonymous namespace)::ToDateTimeTransform64, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTimeTransform64 const&) @ 0x00000000184dd4ea 6. bool DB::callOnIndexAndDataType::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDateTime const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDateTime const&)&&) @ 0x00000000184d7b01 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000184d1fdb 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:26.525134 [ 23610 ] {e3d1e7a3-f66c-4376-86d3-3367264b5cd5} executeQuery: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime from String: In scope SELECT accurateCast('1xxx', 'DateTime'). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: SELECT accurateCast('1xxx', 'DateTime');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/ReadHelpers.cpp:0: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x0000000024720bc6 5. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000184b2df9 6. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018496743 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 17. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 19. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 24. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 30. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 2025.03.05 21:14:26.525410 [ 23610 ] {e3d1e7a3-f66c-4376-86d3-3367264b5cd5} TCPHandler: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime from String: In scope SELECT accurateCast('1xxx', 'DateTime'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/ReadHelpers.cpp:0: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x0000000024720bc6 5. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000184b2df9 6. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018496743 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 17. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 19. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 24. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 30. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 2025.03.05 21:14:26.561492 [ 23610 ] {7f323114-0f1d-4a09-8637-22964c015da8} executeQuery: Code: 70. DB::Exception: Value -1 cannot be safely converted into type UInt16: In scope SELECT accurateCast(-1, 'Date'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: SELECT accurateCast(-1, 'Date');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<_BitInt(8) const&, std::basic_string_view> const&>(int, FormatStringHelperImpl::type, std::basic_string_view::type_identity> const&>::type>, std::basic_string_view::type_identity<_BitInt(8) const&>&&, std::basic_string_view::type_identity> const&>&&) @ 0x00000000187b622a 4. void DB::Transformer, DB::DataTypeDate, DB::(anonymous namespace)::ToDateTransform8Or16Signed, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false, DB::DateTimeAccurateConvertStrategyAdditions>::vector, 4096ul, Allocator, 63ul, 64ul>, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>&, DateLUTImpl const&, DB::DateTimeAccurateConvertStrategyAdditions const&, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>*) @ 0x000000001845361d 5. COW::immutable_ptr> DB::DateTimeTransformImpl, DB::DataTypeDate, DB::(anonymous namespace)::ToDateTransform8Or16Signed, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::DateTimeTransformImpl, DB::DataTypeDate, DB::(anonymous namespace)::ToDateTransform8Or16Signed, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false> const&) @ 0x0000000018452fca 6. bool DB::callOnIndexAndDataType::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDate const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDate const&)&&) @ 0x000000001844c1a1 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000184451fb 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:26.561825 [ 23610 ] {7f323114-0f1d-4a09-8637-22964c015da8} TCPHandler: Code: 70. DB::Exception: Value -1 cannot be safely converted into type UInt16: In scope SELECT accurateCast(-1, 'Date'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<_BitInt(8) const&, std::basic_string_view> const&>(int, FormatStringHelperImpl::type, std::basic_string_view::type_identity> const&>::type>, std::basic_string_view::type_identity<_BitInt(8) const&>&&, std::basic_string_view::type_identity> const&>&&) @ 0x00000000187b622a 4. void DB::Transformer, DB::DataTypeDate, DB::(anonymous namespace)::ToDateTransform8Or16Signed, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false, DB::DateTimeAccurateConvertStrategyAdditions>::vector, 4096ul, Allocator, 63ul, 64ul>, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>&, DateLUTImpl const&, DB::DateTimeAccurateConvertStrategyAdditions const&, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>*) @ 0x000000001845361d 5. COW::immutable_ptr> DB::DateTimeTransformImpl, DB::DataTypeDate, DB::(anonymous namespace)::ToDateTransform8Or16Signed, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::DateTimeTransformImpl, DB::DataTypeDate, DB::(anonymous namespace)::ToDateTransform8Or16Signed, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false> const&) @ 0x0000000018452fca 6. bool DB::callOnIndexAndDataType::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDate const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDate const&)&&) @ 0x000000001844c1a1 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000184451fb 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:26.595791 [ 23610 ] {c154724d-b672-42a8-8a1d-be768cc1008f} executeQuery: Code: 70. DB::Exception: Value 4294967296 cannot be safely converted into type UInt16: In scope SELECT accurateCast(4294967295 + 1, 'Date'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: SELECT accurateCast(0xFFFFFFFF + 1, 'Date');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, unsigned long const&, std::basic_string_view> const&) @ 0x00000000187b5fa2 4. void DB::Transformer, DB::DataTypeDate, DB::(anonymous namespace)::ToDateTransform32Or64, false, DB::DateTimeAccurateConvertStrategyAdditions>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTransform32Or64 const&, DB::PODArray, 63ul, 64ul>*) @ 0x0000000018451a21 5. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDate, DB::(anonymous namespace)::ToDateTransform32Or64, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTransform32Or64 const&) @ 0x000000001845132a 6. bool DB::callOnIndexAndDataType::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDate const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDate const&)&&) @ 0x000000001844a396 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000184451fb 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:26.596048 [ 23610 ] {c154724d-b672-42a8-8a1d-be768cc1008f} TCPHandler: Code: 70. DB::Exception: Value 4294967296 cannot be safely converted into type UInt16: In scope SELECT accurateCast(4294967295 + 1, 'Date'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, unsigned long const&, std::basic_string_view> const&) @ 0x00000000187b5fa2 4. void DB::Transformer, DB::DataTypeDate, DB::(anonymous namespace)::ToDateTransform32Or64, false, DB::DateTimeAccurateConvertStrategyAdditions>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::(anonymous namespace)::ToDateTransform32Or64 const&, DB::PODArray, 63ul, 64ul>*) @ 0x0000000018451a21 5. COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDate, DB::(anonymous namespace)::ToDateTransform32Or64, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::ToDateTransform32Or64 const&) @ 0x000000001845132a 6. bool DB::callOnIndexAndDataType::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDate const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDate const&)&&) @ 0x000000001844a396 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000184451fb 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:26.626337 [ 23610 ] {528f8154-bfe5-40be-a9d1-c54e5c90f606} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: In scope SELECT accurateCast('1xxx', 'Date'). (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: SELECT accurateCast('1xxx', 'Date');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/ReadHelpers.cpp:1142: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&) @ 0x000000002471f74b 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x0000000018653ffb 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018643e8d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 14. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 15. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 18. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 20. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 22. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 25. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:14:26.626352 [ 1474 ] {016f462c-7273-483a-b435-e2d0eb8d513d} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000086 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:26.626634 [ 23610 ] {528f8154-bfe5-40be-a9d1-c54e5c90f606} TCPHandler: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: In scope SELECT accurateCast('1xxx', 'Date'). (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/ReadHelpers.cpp:1142: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&) @ 0x000000002471f74b 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, void*) @ 0x0000000018653ffb 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018643e8d 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018641eef 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 14. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 15. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 18. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 20. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 22. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 25. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 31. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 2025.03.05 21:14:26.626708 [ 1474 ] {016f462c-7273-483a-b435-e2d0eb8d513d} DDLWorker: Query /* ddl_entry=query-0000000086 */ ALTER TABLE test_mihxuc37.t1 ADD COLUMN `newcol` UInt32 wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307967a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:26.679015 [ 23610 ] {ebfca24a-1f73-4248-bc1a-2425332a8e00} executeQuery: Code: 467. DB::Exception: Cannot parse boolean value here: 'test', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: In scope SELECT accurateCast('test', 'Bool'). (CANNOT_PARSE_BOOL) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: select accurateCast('test', 'Bool');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x000000001806cd43 4. ./build_docker/./src/DataTypes/Serializations/SerializationBool.cpp:0: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x000000002f5c35e1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f5c6a0e 6. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f219 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:26.679036 [ 23553 ] {614ba303-e729-46c3-8092-6a2125a46922} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:46740) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:26.679388 [ 23610 ] {ebfca24a-1f73-4248-bc1a-2425332a8e00} TCPHandler: Code: 467. DB::Exception: Cannot parse boolean value here: 'test', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: In scope SELECT accurateCast('test', 'Bool'). (CANNOT_PARSE_BOOL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x000000001806cd43 4. ./build_docker/./src/DataTypes/Serializations/SerializationBool.cpp:0: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x000000002f5c35e1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f5c6a0e 6. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f219 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:26.679497 [ 23553 ] {614ba303-e729-46c3-8092-6a2125a46922} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:26.682701 [ 23610 ] {8b37e530-f758-4f9b-8453-8bd23743547a} executeQuery: Code: 467. DB::Exception: Cannot parse boolean value here: 'truex', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: In scope SELECT accurateCast('truex', 'Bool'). (CANNOT_PARSE_BOOL) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: select accurateCast('truex', 'Bool');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x000000001806cd43 4. ./build_docker/./src/DataTypes/Serializations/SerializationBool.cpp:0: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x000000002f5c35e1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f5c6a0e 6. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f219 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:26.682935 [ 23610 ] {8b37e530-f758-4f9b-8453-8bd23743547a} TCPHandler: Code: 467. DB::Exception: Cannot parse boolean value here: 'truex', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: In scope SELECT accurateCast('truex', 'Bool'). (CANNOT_PARSE_BOOL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x000000001806cd43 4. ./build_docker/./src/DataTypes/Serializations/SerializationBool.cpp:0: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x000000002f5c35e1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f5c6a0e 6. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f219 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:26.685923 [ 23610 ] {bdac79a7-9cd6-4cda-9cea-8efd3391887f} executeQuery: Code: 467. DB::Exception: Cannot parse boolean value here: 'xfalse', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: In scope SELECT accurateCast('xfalse', 'Bool'). (CANNOT_PARSE_BOOL) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: select accurateCast('xfalse', 'Bool');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x000000001806cd43 4. ./build_docker/./src/DataTypes/Serializations/SerializationBool.cpp:0: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x000000002f5c35e1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f5c6a0e 6. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f219 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:26.686283 [ 23610 ] {bdac79a7-9cd6-4cda-9cea-8efd3391887f} TCPHandler: Code: 467. DB::Exception: Cannot parse boolean value here: 'xfalse', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: In scope SELECT accurateCast('xfalse', 'Bool'). (CANNOT_PARSE_BOOL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x000000001806cd43 4. ./build_docker/./src/DataTypes/Serializations/SerializationBool.cpp:0: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x000000002f5c35e1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f5c6a0e 6. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f80d 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000001827f219 8. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:26.707838 [ 23610 ] {76003397-ee77-4b56-91f3-2e1851f0cec4} executeQuery: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT accurateCast('test', 'IPv4'). (CANNOT_PARSE_IPV4) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: select accurateCast('test', 'IPv4');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877b363 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018284f0e 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.708054 [ 23610 ] {76003397-ee77-4b56-91f3-2e1851f0cec4} TCPHandler: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT accurateCast('test', 'IPv4'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877b363 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018284f0e 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.710379 [ 23610 ] {9446cf7c-f790-4112-b17c-437313ba77aa} executeQuery: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT accurateCast('2001:db8::1', 'IPv4'). (CANNOT_PARSE_IPV4) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: select accurateCast('2001:db8::1', 'IPv4');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877b363 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018284f0e 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.710613 [ 23610 ] {9446cf7c-f790-4112-b17c-437313ba77aa} TCPHandler: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT accurateCast('2001:db8::1', 'IPv4'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877b363 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018284f0e 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.712621 [ 23610 ] {a107d829-bf4d-499a-84d2-01cfac40ec36} executeQuery: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT accurateCast('::ffff:192.0.2.1', 'IPv4'). (CANNOT_PARSE_IPV4) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: select accurateCast('::ffff:192.0.2.1', 'IPv4');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877b363 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018284f0e 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.712866 [ 23610 ] {a107d829-bf4d-499a-84d2-01cfac40ec36} TCPHandler: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT accurateCast('::ffff:192.0.2.1', 'IPv4'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877b363 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018284f0e 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.717947 [ 23610 ] {bffd7ee2-482d-4d0f-ab1b-84e01aa94492} executeQuery: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT accurateCast('192.0.2.1x', 'IPv4'). (CANNOT_PARSE_IPV4) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: select accurateCast('192.0.2.1x', 'IPv4');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877b363 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018284f0e 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.718172 [ 23610 ] {bffd7ee2-482d-4d0f-ab1b-84e01aa94492} TCPHandler: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT accurateCast('192.0.2.1x', 'IPv4'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877b363 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018284f0e 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:26.723501 [ 23610 ] {3b794c15-0659-4bce-9e03-40bc4372e44f} executeQuery: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT accurateCast('test', 'IPv6'). (CANNOT_PARSE_IPV6) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: select accurateCast('test', 'IPv6');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877fa3c 5. COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877be2a 6. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182853ee 7. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:14:26.723735 [ 23610 ] {3b794c15-0659-4bce-9e03-40bc4372e44f} TCPHandler: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT accurateCast('test', 'IPv6'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877fa3c 5. COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877be2a 6. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182853ee 7. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:14:26.731035 [ 23610 ] {57cd9263-c529-4e46-9250-8df4042801c8} executeQuery: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT accurateCast('2001:db8::1x', 'IPv6'). (CANNOT_PARSE_IPV6) (version 24.3.12.76.altinitystable) (from [::1]:46690) (comment: 01601_accurate_cast.sql) (in query: select accurateCast('2001:db8::1x', 'IPv6');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877fa3c 5. COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877be2a 6. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182853ee 7. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:14:26.731261 [ 23610 ] {57cd9263-c529-4e46-9250-8df4042801c8} TCPHandler: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT accurateCast('2001:db8::1x', 'IPv6'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877fa3c 5. COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001877be2a 6. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182853ee 7. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:14:26.987787 [ 34946 ] {db291173-e1a5-48fd-8a36-d2c38c929f61} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:46764). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:46764) (comment: 01671_ddl_hang_timeout_long.sh) (in query: ALTER TABLE test_mihxuc37.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:1076: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5a13 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:26.988357 [ 34946 ] {db291173-e1a5-48fd-8a36-d2c38c929f61} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:46764). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:26.988432 [ 34946 ] {db291173-e1a5-48fd-8a36-d2c38c929f61} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:46764). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:1076: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5a13 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:26.988675 [ 34946 ] {db291173-e1a5-48fd-8a36-d2c38c929f61} TCPHandler: Client has gone away. 2025.03.05 21:14:27.946077 [ 23642 ] {3b0fb75b-5080-4ff5-86cb-3ad7dc77d1ae} executeQuery: Code: 6. DB::Exception: Cannot parse string 'a' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION nullIn('a'_String :: 2, __set_11158774537784030992_7151795505194503884 :: 1) -> nullIn('a'_String, __set_11158774537784030992_7151795505194503884) UInt8 : 3'. (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:46782) (comment: 01600_select_in_different_types.sql) (in query: SELECT 'a' IN (SELECT 1) SETTINGS transform_null_in = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182a05c1 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018296bef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000031693477 19. ./build_docker/./src/Interpreters/castColumn.cpp:51: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000031693a44 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000031355e90 21. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cecaa68 22. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 23. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 24. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 25. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 26. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 27. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 28. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 29. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 30. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 2025.03.05 21:14:27.946341 [ 23642 ] {3b0fb75b-5080-4ff5-86cb-3ad7dc77d1ae} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'a' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION nullIn('a'_String :: 2, __set_11158774537784030992_7151795505194503884 :: 1) -> nullIn('a'_String, __set_11158774537784030992_7151795505194503884) UInt8 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182a05c1 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018296bef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000031693477 19. ./build_docker/./src/Interpreters/castColumn.cpp:51: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000031693a44 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000031355e90 21. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cecaa68 22. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 23. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 24. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 25. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 26. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 27. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 28. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 29. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 30. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 2025.03.05 21:14:27.985164 [ 23642 ] {8f8dacdf-9a40-4dd5-bb0a-aa88105883f2} executeQuery: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt8: while executing 'FUNCTION nullIn(-1_Int8 :: 2, __set_11158774537784030992_7151795505194503884 :: 1) -> nullIn(-1_Int8, __set_11158774537784030992_7151795505194503884) UInt8 : 3'. (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:46782) (comment: 01600_select_in_different_types.sql) (in query: SELECT -1 IN (SELECT 1) SETTINGS transform_null_in = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000182ab229 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182a411b 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000031693477 12. ./build_docker/./src/Interpreters/castColumn.cpp:51: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000031693a44 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000031355e90 14. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cecaa68 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 18. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 21. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 22. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 23. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 27. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 28. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 29. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:14:27.985482 [ 23642 ] {8f8dacdf-9a40-4dd5-bb0a-aa88105883f2} TCPHandler: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt8: while executing 'FUNCTION nullIn(-1_Int8 :: 2, __set_11158774537784030992_7151795505194503884 :: 1) -> nullIn(-1_Int8, __set_11158774537784030992_7151795505194503884) UInt8 : 3'. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x00000000182ab229 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000182a411b 6. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000031693477 12. ./build_docker/./src/Interpreters/castColumn.cpp:51: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000031693a44 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000031355e90 14. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cecaa68 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 18. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 21. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 22. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 23. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 27. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 28. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 29. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:14:29.078908 [ 14974 ] {bc8077e5-f09a-4ca1-80c8-6f49d6780144} executeQuery: Code: 252. DB::Exception: Too many parts (10 with average size of 83.00 B) in table 'test_ms4c0uy1.too_many_parts (cf8cac30-962f-4c4e-b662-b1ab94e996ac)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.3.12.76.altinitystable) (from [::1]:46508) (comment: 01603_insert_select_too_many_parts.sql) (in query: -- exception is thrown if threshold is exceeded on new INSERT. INSERT INTO too_many_parts SELECT * FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000032bee462 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000032b6f0db 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51656 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:29.079104 [ 14974 ] {bc8077e5-f09a-4ca1-80c8-6f49d6780144} TCPHandler: Code: 252. DB::Exception: Too many parts (10 with average size of 83.00 B) in table 'test_ms4c0uy1.too_many_parts (cf8cac30-962f-4c4e-b662-b1ab94e996ac)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000032bee462 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000032b6f0db 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51656 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:29.953612 [ 48626 ] {30288473-7657-4805-9ba1-3eaa0a94e9ca} executeQuery: Code: 63. DB::Exception: Aggregate function with name 'abs' does not exist. In scope SELECT number, abs(number) OVER (PARTITION BY toString(intDiv(number, 3)) ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW) FROM numbers(10). (UNKNOWN_AGGREGATE_FUNCTION) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: -- not a window function select number, abs(number) over (partition by toString(intDiv(number, 3)) rows unbounded preceding) from numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000002951b6a3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b67ec 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:29.953881 [ 48626 ] {30288473-7657-4805-9ba1-3eaa0a94e9ca} TCPHandler: Code: 63. DB::Exception: Aggregate function with name 'abs' does not exist. In scope SELECT number, abs(number) OVER (PARTITION BY toString(intDiv(number, 3)) ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW) FROM numbers(10). (UNKNOWN_AGGREGATE_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000002951b6a3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b67ec 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.446493 [ 48626 ] {bb730ea9-a945-42c8-aa52-d27dac9a99d8} executeQuery: Code: 36. DB::Exception: The function 'lagInFrame' can only be used as a window function, not as an aggregate function. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: select lagInFrameOrNull(1) over ();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunction::fail() const @ 0x0000000033c7dd4e 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1524: DB::WindowFunction::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x0000000033c79a7d 6. ./src/AggregateFunctions/IAggregateFunction.h:536: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000033c7b643 7. ./src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:0: DB::AggregateFunctionOrFill::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000028fbdc90 8. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1010: DB::WindowTransform::updateAggregationState() @ 0x0000000033c6a21d 9. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1237: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x0000000033c6b53a 10. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1480: DB::WindowTransform::work() @ 0x0000000033c71452 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 15. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.446700 [ 48626 ] {bb730ea9-a945-42c8-aa52-d27dac9a99d8} TCPHandler: Code: 36. DB::Exception: The function 'lagInFrame' can only be used as a window function, not as an aggregate function. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunction::fail() const @ 0x0000000033c7dd4e 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1524: DB::WindowFunction::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x0000000033c79a7d 6. ./src/AggregateFunctions/IAggregateFunction.h:536: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000033c7b643 7. ./src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:0: DB::AggregateFunctionOrFill::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000028fbdc90 8. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1010: DB::WindowTransform::updateAggregationState() @ 0x0000000033c6a21d 9. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1237: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x0000000033c6b53a 10. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1480: DB::WindowTransform::work() @ 0x0000000033c71452 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 15. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.507486 [ 48626 ] {8357afa9-0b10-42d5-8365-a5963ec995e5} executeQuery: Code: 36. DB::Exception: The offset for function nth_value must be in (0, 9223372036854775807], -1 given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: -- nth_value UBsan SELECT nth_value(1, -1) OVER ();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x0000000033c851da 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x0000000033c84d8e 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::writeOutCurrentRow() @ 0x0000000033c6a847 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1239: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x0000000033c6b57a 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1480: DB::WindowTransform::work() @ 0x0000000033c71452 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.507697 [ 48626 ] {8357afa9-0b10-42d5-8365-a5963ec995e5} TCPHandler: Code: 36. DB::Exception: The offset for function nth_value must be in (0, 9223372036854775807], -1 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x0000000033c851da 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x0000000033c84d8e 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::writeOutCurrentRow() @ 0x0000000033c6a847 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1239: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x0000000033c6b57a 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1480: DB::WindowTransform::work() @ 0x0000000033c71452 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.511536 [ 48626 ] {0f33871e-a763-46c1-b985-613bea6d6409} executeQuery: Code: 36. DB::Exception: The offset for function nth_value must be in (0, 9223372036854775807], 0 given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: SELECT nth_value(1, 0) OVER ();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x0000000033c851da 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x0000000033c84d8e 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::writeOutCurrentRow() @ 0x0000000033c6a847 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1239: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x0000000033c6b57a 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1480: DB::WindowTransform::work() @ 0x0000000033c71452 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.511652 [ 48626 ] {0f33871e-a763-46c1-b985-613bea6d6409} TCPHandler: Code: 36. DB::Exception: The offset for function nth_value must be in (0, 9223372036854775807], 0 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x0000000033c851da 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x0000000033c84d8e 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::writeOutCurrentRow() @ 0x0000000033c6a847 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1239: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x0000000033c6b57a 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1480: DB::WindowTransform::work() @ 0x0000000033c71452 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.515176 [ 48626 ] {4b9be4d7-6eee-49d6-8b14-2db7d0d60e15} executeQuery: Code: 36. DB::Exception: The offset for function nth_value must be in (0, 9223372036854775807], -9223372036854775808 given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: SELECT nth_value(1, /* INT64_MAX+1 */ 0x7fffffffffffffff+1) OVER ();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x0000000033c851da 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x0000000033c84d8e 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::writeOutCurrentRow() @ 0x0000000033c6a847 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1239: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x0000000033c6b57a 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1480: DB::WindowTransform::work() @ 0x0000000033c71452 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.515285 [ 48626 ] {4b9be4d7-6eee-49d6-8b14-2db7d0d60e15} TCPHandler: Code: 36. DB::Exception: The offset for function nth_value must be in (0, 9223372036854775807], -9223372036854775808 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x0000000033c851da 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x0000000033c84d8e 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::writeOutCurrentRow() @ 0x0000000033c6a847 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1239: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x0000000033c6b57a 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1480: DB::WindowTransform::work() @ 0x0000000033c71452 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.542881 [ 48626 ] {ebdc7eb5-5133-49c9-963a-aa87a142a664} executeQuery: Code: 36. DB::Exception: The offset for function lagInFrame must be in (0, 9223372036854775807], -1 given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: -- lagInFrame UBsan SELECT lagInFrame(1, -1) OVER ();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x0000000033c851da 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x0000000033c88a57 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::writeOutCurrentRow() @ 0x0000000033c6a847 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1239: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x0000000033c6b57a 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1480: DB::WindowTransform::work() @ 0x0000000033c71452 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.543050 [ 48626 ] {ebdc7eb5-5133-49c9-963a-aa87a142a664} TCPHandler: Code: 36. DB::Exception: The offset for function lagInFrame must be in (0, 9223372036854775807], -1 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x0000000033c851da 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x0000000033c88a57 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::writeOutCurrentRow() @ 0x0000000033c6a847 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1239: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x0000000033c6b57a 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1480: DB::WindowTransform::work() @ 0x0000000033c71452 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.548997 [ 48626 ] {445a09ad-7f53-4e9d-858f-023f7fbb4d64} executeQuery: Code: 36. DB::Exception: The offset for function lagInFrame must be in (0, 9223372036854775807], -9223372036854775808 given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: SELECT lagInFrame(1, /* INT64_MAX+1 */ 0x7fffffffffffffff+1) OVER ();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x0000000033c851da 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x0000000033c88a57 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::writeOutCurrentRow() @ 0x0000000033c6a847 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1239: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x0000000033c6b57a 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1480: DB::WindowTransform::work() @ 0x0000000033c71452 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.549091 [ 48626 ] {445a09ad-7f53-4e9d-858f-023f7fbb4d64} TCPHandler: Code: 36. DB::Exception: The offset for function lagInFrame must be in (0, 9223372036854775807], -9223372036854775808 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x0000000033c851da 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x0000000033c88a57 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::writeOutCurrentRow() @ 0x0000000033c6a847 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1239: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x0000000033c6b57a 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1480: DB::WindowTransform::work() @ 0x0000000033c71452 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.574176 [ 48626 ] {9c9000fa-0352-4131-82b4-12c752d7e3a0} executeQuery: Code: 36. DB::Exception: The offset for function leadInFrame must be in (0, 9223372036854775807], -1 given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: -- leadInFrame UBsan SELECT leadInFrame(1, -1) OVER ();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x0000000033c851da 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x0000000033c8c1c3 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::writeOutCurrentRow() @ 0x0000000033c6a847 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1239: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x0000000033c6b57a 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1480: DB::WindowTransform::work() @ 0x0000000033c71452 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.574397 [ 48626 ] {9c9000fa-0352-4131-82b4-12c752d7e3a0} TCPHandler: Code: 36. DB::Exception: The offset for function leadInFrame must be in (0, 9223372036854775807], -1 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x0000000033c851da 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x0000000033c8c1c3 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::writeOutCurrentRow() @ 0x0000000033c6a847 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1239: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x0000000033c6b57a 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1480: DB::WindowTransform::work() @ 0x0000000033c71452 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.582814 [ 48626 ] {b9feade8-2da1-41d9-a854-7a95b83c2f33} executeQuery: Code: 36. DB::Exception: The offset for function leadInFrame must be in (0, 9223372036854775807], -9223372036854775808 given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: SELECT leadInFrame(1, /* INT64_MAX+1 */ 0x7fffffffffffffff+1) OVER ();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x0000000033c851da 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x0000000033c8c1c3 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::writeOutCurrentRow() @ 0x0000000033c6a847 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1239: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x0000000033c6b57a 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1480: DB::WindowTransform::work() @ 0x0000000033c71452 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.582965 [ 48626 ] {b9feade8-2da1-41d9-a854-7a95b83c2f33} TCPHandler: Code: 36. DB::Exception: The offset for function leadInFrame must be in (0, 9223372036854775807], -9223372036854775808 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x0000000033c851da 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x0000000033c8c1c3 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::writeOutCurrentRow() @ 0x0000000033c6a847 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1239: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x0000000033c6b57a 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1480: DB::WindowTransform::work() @ 0x0000000033c71452 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.622317 [ 48626 ] {2f4d95f0-717b-4d7b-9af8-3c50cf8bdb49} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'String' given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: -- nth_value Msan SELECT nth_value(1, '') OVER ();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionNthValue::WindowFunctionNthValue(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c84008 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c83662 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c833ac 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c73768 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.622521 [ 48626 ] {2f4d95f0-717b-4d7b-9af8-3c50cf8bdb49} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'String' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionNthValue::WindowFunctionNthValue(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c84008 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c83662 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c833ac 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c73768 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.654323 [ 48626 ] {ac51c308-ad86-432d-9bfb-d46ef834354f} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'String' given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: -- lagInFrame Msan SELECT lagInFrame(1, '') OVER ();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionLagLeadInFrame::WindowFunctionLagLeadInFrame(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c86be7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator>, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c85bc2 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr> std::allocate_shared[abi:v15000], std::allocator>, String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c8590c 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c737c8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.654538 [ 48626 ] {ac51c308-ad86-432d-9bfb-d46ef834354f} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'String' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionLagLeadInFrame::WindowFunctionLagLeadInFrame(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c86be7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator>, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c85bc2 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr> std::allocate_shared[abi:v15000], std::allocator>, String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c8590c 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c737c8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.694082 [ 48626 ] {f7a23da5-e779-4e87-a4c1-ee2efb2b78de} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'String' given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: -- leadInFrame Msan SELECT leadInFrame(1, '') OVER ();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionLagLeadInFrame::WindowFunctionLagLeadInFrame(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c8a5e7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator>, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c895c2 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr> std::allocate_shared[abi:v15000], std::allocator>, String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c8930c 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c73828 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.694332 [ 48626 ] {f7a23da5-e779-4e87-a4c1-ee2efb2b78de} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'String' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowFunctionLagLeadInFrame::WindowFunctionLagLeadInFrame(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c8a5e7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:v15000], std::allocator>> const&, DB::Array const&>(std::allocator>, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c895c2 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr> std::allocate_shared[abi:v15000], std::allocator>, String const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000033c8930c 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000033c73828 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad702 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.707085 [ 48626 ] {59650ebe-475c-4869-80df-4734e6ea5f4a} executeQuery: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: -- negative offsets should not be allowed select count() over (order by toInt64(number) range between -1 preceding and unbounded following) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x00000000316684ca 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:0: DB::WindowFrame::checkValid() const @ 0x0000000031667dc3 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.707208 [ 48626 ] {59650ebe-475c-4869-80df-4734e6ea5f4a} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x00000000316684ca 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:0: DB::WindowFrame::checkValid() const @ 0x0000000031667dc3 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.708923 [ 48626 ] {7a5ca3ff-84b5-4dc8-b60a-e27335a34faf} executeQuery: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: select count() over (order by toInt64(number) range between -1 following and unbounded following) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x00000000316684ca 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:0: DB::WindowFrame::checkValid() const @ 0x0000000031667dc3 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.709091 [ 48626 ] {7a5ca3ff-84b5-4dc8-b60a-e27335a34faf} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x00000000316684ca 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:0: DB::WindowFrame::checkValid() const @ 0x0000000031667dc3 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.711246 [ 48626 ] {e4bf40eb-5b32-4d87-9680-2d57a0d957da} executeQuery: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: select count() over (order by toInt64(number) range between unbounded preceding and -1 preceding) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x00000000316684ca 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:0: DB::WindowFrame::checkValid() const @ 0x0000000031667e8f 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.711411 [ 48626 ] {e4bf40eb-5b32-4d87-9680-2d57a0d957da} TCPHandler: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x00000000316684ca 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:0: DB::WindowFrame::checkValid() const @ 0x0000000031667e8f 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.713401 [ 48626 ] {f663c0b4-dd5b-4e1a-b441-ca6395af89c6} executeQuery: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: select count() over (order by toInt64(number) range between unbounded preceding and -1 following) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x00000000316684ca 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:0: DB::WindowFrame::checkValid() const @ 0x0000000031667e8f 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.713617 [ 48626 ] {f663c0b4-dd5b-4e1a-b441-ca6395af89c6} TCPHandler: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x00000000316684ca 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:0: DB::WindowFrame::checkValid() const @ 0x0000000031667e8f 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.979597 [ 48626 ] {6a234cf0-e8c7-464b-804b-78384992de11} executeQuery: Code: 36. DB::Exception: Frame start offset for 'ROWS' frame must be a nonnegative 32-bit integer, '2147483648' of type 'UInt64' given. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: -- -INT_MIN row offset that can lead to problems with negation, found when fuzzing -- under UBSan. Should be limited to at most INT_MAX. select count() over (rows between 2147483648 preceding and 2147493648 following) from numbers(2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x00000000316684ca 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:0: DB::WindowFrame::checkValid() const @ 0x0000000031667dc3 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:30.979759 [ 48626 ] {6a234cf0-e8c7-464b-804b-78384992de11} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'ROWS' frame must be a nonnegative 32-bit integer, '2147483648' of type 'UInt64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x00000000316684ca 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:0: DB::WindowFrame::checkValid() const @ 0x0000000031667dc3 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:31.024020 [ 48626 ] {d729231b-3e53-4bc6-aaa1-85e245555756} executeQuery: Code: 36. DB::Exception: Derived window definition 'w PARTITION BY number' is not allowed to override PARTITION BY. In scope SELECT count() OVER (w PARTITION BY number) FROM numbers(1) WINDOW w AS (PARTITION BY intDiv(number, 5)). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: -- can't redefine PARTITION BY select count() over (w partition by number) from numbers(1) window w as (partition by intDiv(number, 5));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::mergeWindowWithParentWindow(std::shared_ptr const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003088eafe 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c2df0 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:31.024235 [ 48626 ] {d729231b-3e53-4bc6-aaa1-85e245555756} TCPHandler: Code: 36. DB::Exception: Derived window definition 'w PARTITION BY number' is not allowed to override PARTITION BY. In scope SELECT count() OVER (w PARTITION BY number) FROM numbers(1) WINDOW w AS (PARTITION BY intDiv(number, 5)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::mergeWindowWithParentWindow(std::shared_ptr const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003088eafe 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c2df0 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:31.050703 [ 48626 ] {45b86660-df1d-4022-8b58-61f87f51d373} executeQuery: Code: 36. DB::Exception: Derived window definition 'w ORDER BY number ASC' is not allowed to override a non-empty ORDER BY. In scope SELECT count() OVER (w ORDER BY number ASC) FROM numbers(1) WINDOW w AS (PARTITION BY intDiv(number, 5) ORDER BY mod(number, 3) ASC). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: -- can't redefine existing ORDER BY select count() over (w order by number) from numbers(1) window w as (partition by intDiv(number, 5) order by mod(number, 3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::mergeWindowWithParentWindow(std::shared_ptr const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003088ef2d 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c2df0 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:31.050974 [ 48626 ] {45b86660-df1d-4022-8b58-61f87f51d373} TCPHandler: Code: 36. DB::Exception: Derived window definition 'w ORDER BY number ASC' is not allowed to override a non-empty ORDER BY. In scope SELECT count() OVER (w ORDER BY number ASC) FROM numbers(1) WINDOW w AS (PARTITION BY intDiv(number, 5) ORDER BY mod(number, 3) ASC). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::mergeWindowWithParentWindow(std::shared_ptr const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003088ef2d 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c2df0 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:31.074962 [ 48626 ] {7519777c-b7db-40ad-ae45-4033bdf9f996} executeQuery: Code: 36. DB::Exception: Parent window 'w' is not allowed to define a frame: while processing derived window definition 'w RANGE BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW'. In scope SELECT count() OVER (w RANGE BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW) FROM numbers(1) WINDOW w AS (PARTITION BY intDiv(number, 5) ORDER BY mod(number, 3) ASC ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: -- parent window can't have frame select count() over (w range unbounded preceding) from numbers(1) window w as (partition by intDiv(number, 5) order by mod(number, 3) rows unbounded preceding);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000002951b6a3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::mergeWindowWithParentWindow(std::shared_ptr const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003088ed22 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c2df0 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:31.075191 [ 48626 ] {7519777c-b7db-40ad-ae45-4033bdf9f996} TCPHandler: Code: 36. DB::Exception: Parent window 'w' is not allowed to define a frame: while processing derived window definition 'w RANGE BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW'. In scope SELECT count() OVER (w RANGE BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW) FROM numbers(1) WINDOW w AS (PARTITION BY intDiv(number, 5) ORDER BY mod(number, 3) ASC ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000002951b6a3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::mergeWindowWithParentWindow(std::shared_ptr const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003088ed22 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c2df0 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:31.105545 [ 48626 ] {c159b05a-4d00-4a76-bf78-4efc7db9c79a} executeQuery: Code: 36. DB::Exception: Window 'w2' does not exist. In scope SELECT count() OVER (w2 ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01591_window_functions.sql) (in query: -- nonexistent parent window select count() over (w2 rows unbounded preceding);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000001aa90eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c552b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:31.105747 [ 48626 ] {c159b05a-4d00-4a76-bf78-4efc7db9c79a} TCPHandler: Code: 36. DB::Exception: Window 'w2' does not exist. In scope SELECT count() OVER (w2 ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000001aa90eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c552b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 6. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 9. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:31.344084 [ 23620 ] {3147ebb7-698d-4d8b-8f4b-d5dadd0b0072} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt64(inf). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:40166) (comment: 01581_to_int_inf_nan.sql) (in query: SELECT toInt64(inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001837a0bc 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.344266 [ 23620 ] {3147ebb7-698d-4d8b-8f4b-d5dadd0b0072} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt64(inf). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001837a0bc 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.372157 [ 23620 ] {b13afa69-fe3f-49b5-9fdd-504a6ed2d9b9} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt128(inf). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:40166) (comment: 01581_to_int_inf_nan.sql) (in query: SELECT toInt128(inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018391ff4 5. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001838956f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.372322 [ 23620 ] {b13afa69-fe3f-49b5-9fdd-504a6ed2d9b9} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt128(inf). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018391ff4 5. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001838956f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.400324 [ 23620 ] {337e1fc0-a055-4c51-81e1-24abdb277e80} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt256(inf). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:40166) (comment: 01581_to_int_inf_nan.sql) (in query: SELECT toInt256(inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000183aabbe 5. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000183a172f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.400545 [ 23620 ] {337e1fc0-a055-4c51-81e1-24abdb277e80} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt256(inf). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000183aabbe 5. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000183a172f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.402687 [ 23620 ] {87d16c48-be1b-4389-b75a-0e2abfccb450} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt64(nan). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:40166) (comment: 01581_to_int_inf_nan.sql) (in query: SELECT toInt64(nan);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001837a0bc 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.402830 [ 23620 ] {87d16c48-be1b-4389-b75a-0e2abfccb450} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt64(nan). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001837a0bc 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018371b0f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.404359 [ 23620 ] {1950710a-a4b5-4828-bec7-e961b23049cc} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt128(nan). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:40166) (comment: 01581_to_int_inf_nan.sql) (in query: SELECT toInt128(nan);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018391ff4 5. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001838956f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.404498 [ 23620 ] {1950710a-a4b5-4828-bec7-e961b23049cc} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt128(nan). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018391ff4 5. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt128, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001838956f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.405895 [ 23620 ] {4d4fa5a3-26e1-4123-bbc4-9e6fa1f27f3b} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt256(nan). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:40166) (comment: 01581_to_int_inf_nan.sql) (in query: SELECT toInt256(nan);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000183aabbe 5. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000183a172f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.406011 [ 23620 ] {4d4fa5a3-26e1-4123-bbc4-9e6fa1f27f3b} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt256(nan). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000183aabbe 5. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000183a172f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.433367 [ 23620 ] {218911c1-6b79-4fe1-897a-bb8699b36536} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toUInt64(inf). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:40166) (comment: 01581_to_int_inf_nan.sql) (in query: SELECT toUInt64(inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182e9988 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182e12ef 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.433575 [ 23620 ] {218911c1-6b79-4fe1-897a-bb8699b36536} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toUInt64(inf). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182e9988 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182e12ef 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.461555 [ 23620 ] {a03dcee0-0f02-45fa-a212-c4b4dd491265} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toUInt256(inf). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:40166) (comment: 01581_to_int_inf_nan.sql) (in query: SELECT toUInt256(inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToUInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToUInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001831b095 5. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToUInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018311e2f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.487250 [ 23621 ] {afa25d3b-4088-48a7-834e-32ad54f50797} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt64, Int8 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT toTypeName([-1, toUInt64(1)]). (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:40180) (comment: 01579_date_datetime_index_comparison.sql) (in query: -- We don't promote to wide integers select toTypeName([-1, toUInt64(1)]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002f58a328 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002f58a0f4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:631: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58e9fb 7. DB::FunctionArray::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000021f03507 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:31.487255 [ 23620 ] {a03dcee0-0f02-45fa-a212-c4b4dd491265} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toUInt256(inf). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToUInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToUInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001831b095 5. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToUInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018311e2f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.487527 [ 23621 ] {afa25d3b-4088-48a7-834e-32ad54f50797} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt64, Int8 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT toTypeName([-1, toUInt64(1)]). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002f58a328 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002f58a0f4 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:631: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58e9fb 7. DB::FunctionArray::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000021f03507 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:478: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e8441b1 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:14:31.489400 [ 23620 ] {844da58d-0988-448c-a4c7-0f0e642144a7} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toUInt64(nan). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:40166) (comment: 01581_to_int_inf_nan.sql) (in query: SELECT toUInt64(nan);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182e9988 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182e12ef 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.489546 [ 23620 ] {844da58d-0988-448c-a4c7-0f0e642144a7} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toUInt64(nan). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182e9988 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182e12ef 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.491053 [ 23620 ] {10863f39-6220-4176-b401-a0678d83a6c7} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toUInt256(nan). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:40166) (comment: 01581_to_int_inf_nan.sql) (in query: SELECT toUInt256(nan);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToUInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToUInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001831b095 5. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToUInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018311e2f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.491180 [ 23620 ] {10863f39-6220-4176-b401-a0678d83a6c7} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toUInt256(nan). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToUInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToUInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001831b095 5. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToUInt256, DB::(anonymous namespace)::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018311e2f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:31.794864 [ 22863 ] {e0671e33-ddf1-4752-8c79-8c10e8611720} executeQuery: Code: 36. DB::Exception: Frame start offset 2 FOLLOWING does not precede the frame end offset 0 FOLLOWING. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40194) (comment: 01571_window_functions.sql) (in query: -- signed and unsigned in offset do not cause logical error select count() over (rows between 2 following and 1 + -1 following) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Field const&, char const (&) [10], DB::Field const&, char const (&) [10]) @ 0x0000000031668753 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:179: DB::WindowFrame::checkValid() const @ 0x0000000031667f6a 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:31.825547 [ 14920 ] {3adb994a-77f5-4eb2-b950-58e8470ca1c4} executeQuery: Code: 36. DB::Exception: Unsupported aggregate function count, supported functions are any,anyLast,min,max,sum,sumWithOverflow,groupBitAnd,groupBitOr,groupBitXor,sumMap,minMap,maxMap,groupArrayArray,groupArrayLastArray,groupUniqArrayArray,sumMappedArrays,minMappedArrays,maxMappedArrays. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40188) (comment: 01570_aggregator_combinator_simple_state.sql) (in query: -- non-SimpleAggregateFunction with countSimpleState(number) as c select toTypeName(c), c from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/DataTypes/DataTypeCustomSimpleAggregateFunction.cpp:0: DB::DataTypeCustomSimpleAggregateFunction::checkSupportedFunctions(std::shared_ptr const&) @ 0x000000002f45bd02 5. ./src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:35: DB::AggregateFunctionSimpleState::createResultType(std::shared_ptr const&, DB::Array const&) @ 0x0000000028f81ddf 6. ./src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:23: DB::AggregateFunctionSimpleState::AggregateFunctionSimpleState(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028f81b6e 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::AggregateFunctionSimpleState* std::construct_at[abi:v15000] const&, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionSimpleState*>(DB::AggregateFunctionSimpleState*, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028fdfc78 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000] const&, std::vector, std::allocator>> const&, DB::Array const&>(std::allocator, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028fdfa86 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028fdf7ec 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: DB::(anonymous namespace)::AggregateFunctionCombinatorSimpleState::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028fdf757 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 12. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:14:31.825551 [ 22863 ] {e0671e33-ddf1-4752-8c79-8c10e8611720} TCPHandler: Code: 36. DB::Exception: Frame start offset 2 FOLLOWING does not precede the frame end offset 0 FOLLOWING. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Field const&, char const (&) [10], DB::Field const&, char const (&) [10]) @ 0x0000000031668753 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:179: DB::WindowFrame::checkValid() const @ 0x0000000031667f6a 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c3ab2 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5904: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308ad8cc 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:31.825771 [ 14920 ] {3adb994a-77f5-4eb2-b950-58e8470ca1c4} TCPHandler: Code: 36. DB::Exception: Unsupported aggregate function count, supported functions are any,anyLast,min,max,sum,sumWithOverflow,groupBitAnd,groupBitOr,groupBitXor,sumMap,minMap,maxMap,groupArrayArray,groupArrayLastArray,groupUniqArrayArray,sumMappedArrays,minMappedArrays,maxMappedArrays. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/DataTypes/DataTypeCustomSimpleAggregateFunction.cpp:0: DB::DataTypeCustomSimpleAggregateFunction::checkSupportedFunctions(std::shared_ptr const&) @ 0x000000002f45bd02 5. ./src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:35: DB::AggregateFunctionSimpleState::createResultType(std::shared_ptr const&, DB::Array const&) @ 0x0000000028f81ddf 6. ./src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:23: DB::AggregateFunctionSimpleState::AggregateFunctionSimpleState(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028f81b6e 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::AggregateFunctionSimpleState* std::construct_at[abi:v15000] const&, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionSimpleState*>(DB::AggregateFunctionSimpleState*, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028fdfc78 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000] const&, std::vector, std::allocator>> const&, DB::Array const&>(std::allocator, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028fdfa86 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028fdf7ec 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: DB::(anonymous namespace)::AggregateFunctionCombinatorSimpleState::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028fdf757 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 12. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:14:32.351950 [ 22859 ] {3bd54e1f-9efd-4d8e-9f15-9ddcb432ea48} executeQuery: Code: 48. DB::Exception: Window functions does not support processing from WithMergeableStateAfterAggregation. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:40196) (comment: 01568_window_functions_distributed.sql) (in query: select groupArray(groupArray(number)) over (rows unbounded preceding) as x from remote('127.0.0.{1,2}', '', t_01568) group by mod(number, 3) order by x settings distributed_group_by_no_merge=2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x0000000031010c85 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:32.352120 [ 22859 ] {3bd54e1f-9efd-4d8e-9f15-9ddcb432ea48} TCPHandler: Code: 48. DB::Exception: Window functions does not support processing from WithMergeableStateAfterAggregation. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x0000000031010c85 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:32.583553 [ 22866 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:33506). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:32.583667 [ 23587 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:54758). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:32.583779 [ 48599 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:54554). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:32.583922 [ 23621 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:57990). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:32.584571 [ 23610 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:40702). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:32.630270 [ 14920 ] {2bd2ffc5-62ae-4e99-971e-aba5bc0f1473} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'nonexistent' in scope SELECT nonexistent AS column. (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:40222) (comment: 01564_test_hint_woes.sql) (in query: select nonexistent column;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 7. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:32.630488 [ 14920 ] {2bd2ffc5-62ae-4e99-971e-aba5bc0f1473} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'nonexistent' in scope SELECT nonexistent AS column. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 7. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:32.635246 [ 14920 ] {f1656261-77fd-4973-a8ba-cdac82e95c01} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'nonexistent' in scope SELECT nonexistent AS column. (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:40222) (comment: 01564_test_hint_woes.sql) (in query: select nonexistent column;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 7. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:32.635364 [ 14920 ] {f1656261-77fd-4973-a8ba-cdac82e95c01} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'nonexistent' in scope SELECT nonexistent AS column. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 7. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:32.637657 [ 14920 ] {e5383640-78bd-43db-8b5e-cf404b41069f} executeQuery: Code: 469. DB::Exception: Constraint `c1` for table test_axjsrt8r.values_01564 (26e01eee-38f3-41a4-9daa-60bf4d1d1ac9) is violated at row 1. Expression: (a < 10). Column values: a = 11. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:40222) (comment: 01564_test_hint_woes.sql) (in query: -- server error hint after broken insert values (violated constraint) insert into values_01564 values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:32.637726 [ 14920 ] {e5383640-78bd-43db-8b5e-cf404b41069f} TCPHandler: Code: 469. DB::Exception: Constraint `c1` for table test_axjsrt8r.values_01564 (26e01eee-38f3-41a4-9daa-60bf4d1d1ac9) is violated at row 1. Expression: (a < 10). Column values: a = 11. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:32.640545 [ 14920 ] {b6cfefe6-b539-474c-8eed-298e3bf6da1b} executeQuery: Code: 469. DB::Exception: Constraint `c1` for table test_axjsrt8r.values_01564 (26e01eee-38f3-41a4-9daa-60bf4d1d1ac9) is violated at row 1. Expression: (a < 10). Column values: a = 11. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:40222) (comment: 01564_test_hint_woes.sql) (in query: insert into values_01564 values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:32.640617 [ 14920 ] {b6cfefe6-b539-474c-8eed-298e3bf6da1b} TCPHandler: Code: 469. DB::Exception: Constraint `c1` for table test_axjsrt8r.values_01564 (26e01eee-38f3-41a4-9daa-60bf4d1d1ac9) is violated at row 1. Expression: (a < 10). Column values: a = 11. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:32.645432 [ 14920 ] {05d68f64-4526-42b6-b734-bf773ea7dd18} executeQuery: Code: 469. DB::Exception: Constraint `c1` for table test_axjsrt8r.values_01564 (26e01eee-38f3-41a4-9daa-60bf4d1d1ac9) is violated at row 1. Expression: (a < 10). Column values: a = 11. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:40222) (comment: 01564_test_hint_woes.sql) (in query: insert into values_01564 values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:32.645513 [ 14920 ] {05d68f64-4526-42b6-b734-bf773ea7dd18} TCPHandler: Code: 469. DB::Exception: Constraint `c1` for table test_axjsrt8r.values_01564 (26e01eee-38f3-41a4-9daa-60bf4d1d1ac9) is violated at row 1. Expression: (a < 10). Column values: a = 11. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:32.647242 [ 14920 ] {fba0c336-1c2f-46c6-b2a9-cde2048656c0} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'nonexistent' in scope SELECT nonexistent AS column. (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:40222) (comment: 01564_test_hint_woes.sql) (in query: select nonexistent column;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 7. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:32.647416 [ 14920 ] {fba0c336-1c2f-46c6-b2a9-cde2048656c0} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'nonexistent' in scope SELECT nonexistent AS column. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 7. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:32.666628 [ 14920 ] {c06e97f0-e502-4430-aec7-9f0d25b12761} executeQuery: Code: 469. DB::Exception: Constraint `c1` for table test_axjsrt8r.values_01564 (26e01eee-38f3-41a4-9daa-60bf4d1d1ac9) is violated at row 1. Expression: (a < 10). Column values: a = 11. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:40222) (comment: 01564_test_hint_woes.sql) (in query: -- the return code must be zero after the final query has failed with expected error insert into values_01564 values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:32.666753 [ 14920 ] {c06e97f0-e502-4430-aec7-9f0d25b12761} TCPHandler: Code: 469. DB::Exception: Constraint `c1` for table test_axjsrt8r.values_01564 (26e01eee-38f3-41a4-9daa-60bf4d1d1ac9) is violated at row 1. Expression: (a < 10). Column values: a = 11. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:32.734890 [ 48611 ] {5c09a8c9-e945-4c19-a15e-00698cfbe8ef} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:34458). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:34458) (comment: 01602_max_distributed_connections.sh) (in query: SELECT sleep(0.15) AS `sleep(0.15)` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5be4 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:32.735248 [ 48611 ] {5c09a8c9-e945-4c19-a15e-00698cfbe8ef} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:34458). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:32.735305 [ 48611 ] {5c09a8c9-e945-4c19-a15e-00698cfbe8ef} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:34458). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5be4 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:32.735456 [ 48611 ] {5c09a8c9-e945-4c19-a15e-00698cfbe8ef} TCPHandler: Client has gone away. 2025.03.05 21:14:33.266660 [ 14920 ] {01572_kill_window_function-test_aj3ic38r} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:40266) (comment: 01572_kill_window_function.sh) (in query: SELECT sum(number) OVER (PARTITION BY number % 10 ORDER BY number DESC NULLS FIRST ROWS BETWEEN CURRENT ROW AND 99999 FOLLOWING) FROM numbers(0, 10000000) format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:33.268111 [ 14920 ] {01572_kill_window_function-test_aj3ic38r} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003355895a 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:33.599055 [ 23573 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:40708). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:33.599201 [ 14920 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:33518). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:33.599621 [ 48600 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:58064). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:33.600164 [ 48602 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:54564). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:33.750947 [ 23628 ] {1c249747-9e9a-4b79-9fb5-b6c38ec33bac} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:59850). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:59850) (comment: 01602_max_distributed_connections.sh) (in query: SELECT sleep(0.15) AS `sleep(0.15)` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5be4 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:33.751065 [ 48605 ] {f2c62210-9f1a-4292-bc54-f0e4481c14c3} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:34468). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:34468) (comment: 01602_max_distributed_connections.sh) (in query: SELECT sleep(0.15) AS `sleep(0.15)` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5be4 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:33.751467 [ 23628 ] {1c249747-9e9a-4b79-9fb5-b6c38ec33bac} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:59850). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:33.751488 [ 48605 ] {f2c62210-9f1a-4292-bc54-f0e4481c14c3} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:34468). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:33.751521 [ 23628 ] {1c249747-9e9a-4b79-9fb5-b6c38ec33bac} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:59850). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5be4 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:33.751541 [ 48605 ] {f2c62210-9f1a-4292-bc54-f0e4481c14c3} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:34468). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5be4 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:33.751698 [ 23628 ] {1c249747-9e9a-4b79-9fb5-b6c38ec33bac} TCPHandler: Client has gone away. 2025.03.05 21:14:33.751729 [ 48605 ] {f2c62210-9f1a-4292-bc54-f0e4481c14c3} TCPHandler: Client has gone away. 2025.03.05 21:14:34.125497 [ 23553 ] {0fa9ec19-751a-42d3-8912-71215d50a2a1} executeQuery: Code: 36. DB::Exception: All numbers in both samples are identical: While executing ConvertingAggregatedToChunksTransform. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40340) (comment: 01560_mann_whitney.sql) (in query: WITH mannWhitneyUTest('two-sided')(1, right) AS pair SELECT roundBankers(pair.1, 16) AS t_stat, roundBankers(pair.2, 16) AS p_value FROM mann_whitney_test;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./src/AggregateFunctions/StatCommon.h:51: DB::(anonymous namespace)::AggregateFunctionMannWhitney::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x0000000028a012c4 5. ./build_docker/./src/Interpreters/Aggregator.cpp:1930: void DB::Aggregator::insertAggregatesIntoColumns(char*&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::Arena*) const @ 0x000000002ff1c7a9 6. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::prepareBlockAndFillWithoutKey(DB::AggregatedDataVariants&, bool, bool) const @ 0x000000002fe69f69 7. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:471: DB::ConvertingAggregatedToChunksTransform::initialize() @ 0x0000000033e54b13 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:34.125913 [ 23553 ] {0fa9ec19-751a-42d3-8912-71215d50a2a1} TCPHandler: Code: 36. DB::Exception: All numbers in both samples are identical: While executing ConvertingAggregatedToChunksTransform. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./src/AggregateFunctions/StatCommon.h:51: DB::(anonymous namespace)::AggregateFunctionMannWhitney::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x0000000028a012c4 5. ./build_docker/./src/Interpreters/Aggregator.cpp:1930: void DB::Aggregator::insertAggregatesIntoColumns(char*&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::Arena*) const @ 0x000000002ff1c7a9 6. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::prepareBlockAndFillWithoutKey(DB::AggregatedDataVariants&, bool, bool) const @ 0x000000002fe69f69 7. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:471: DB::ConvertingAggregatedToChunksTransform::initialize() @ 0x0000000033e54b13 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 11. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 12. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:34.589728 [ 34946 ] {108ea9da-6b2c-4cad-bdf0-9076e7f0819b} executeQuery: Code: 70. DB::Exception: Cannot convert infinite value to integer type. (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:40368) (comment: 01557_field_infinite_convert_to_number.sql) (in query: SET max_threads = nan;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Core/SettingsFields.cpp:0: unsigned long DB::(anonymous namespace)::fieldToNumber(DB::Field const&) @ 0x000000002f3689a5 5. ./src/Core/SettingsFields.h:148: DB::SettingFieldMaxThreads::SettingFieldMaxThreads(DB::Field const&) @ 0x000000002f36b6ae 6. ./build_docker/./src/Core/Settings.cpp:21: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda31'(DB::Field const&)::__invoke(DB::Field const&) @ 0x000000002f1ca59d 7. ./src/Core/Settings.h:0: DB::BaseSettings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x000000002eed3dee 8. ./build_docker/./src/Access/SettingsConstraints.cpp:0: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x000000002eed26d1 9. ./build_docker/./src/Access/SettingsConstraints.cpp:285: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a3d 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002eed0ee2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002fc65656 12. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x00000000310cdc3d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:34.589943 [ 34946 ] {108ea9da-6b2c-4cad-bdf0-9076e7f0819b} TCPHandler: Code: 70. DB::Exception: Cannot convert infinite value to integer type. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Core/SettingsFields.cpp:0: unsigned long DB::(anonymous namespace)::fieldToNumber(DB::Field const&) @ 0x000000002f3689a5 5. ./src/Core/SettingsFields.h:148: DB::SettingFieldMaxThreads::SettingFieldMaxThreads(DB::Field const&) @ 0x000000002f36b6ae 6. ./build_docker/./src/Core/Settings.cpp:21: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda31'(DB::Field const&)::__invoke(DB::Field const&) @ 0x000000002f1ca59d 7. ./src/Core/Settings.h:0: DB::BaseSettings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x000000002eed3dee 8. ./build_docker/./src/Access/SettingsConstraints.cpp:0: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x000000002eed26d1 9. ./build_docker/./src/Access/SettingsConstraints.cpp:285: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a3d 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002eed0ee2 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002fc65656 12. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x00000000310cdc3d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.391569 [ 48598 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:35.391886 [ 48598 ] {} ServerErrorHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:35.415465 [ 5753 ] {bd393622-4179-4244-aae1-b3fe8d2dca3a} executeQuery: Code: 516. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 : While sending /var/lib/clickhouse/store/1ec/1ec9b2a5-961d-415d-8f79-a2b74cba15a2/default:foo@127%2E0%2E0%2E1:9000,default:foo@127%2E0%2E0%2E2:9000/1.bin. (AUTHENTICATION_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:40462) (comment: 01555_system_distribution_queue_mask.sql) (in query: -- since test_cluster_with_incorrect_pw contains incorrect password ignore error system flush distributed dist_01555;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:452: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x0000000033278953 6. ./build_docker/./src/Client/Connection.cpp:202: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003327463e 7. ./build_docker/./src/Client/Connection.cpp:512: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003327d0a6 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:44: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&) @ 0x000000003329673f 9. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:0: DB::ConnectionPoolWithFailover::tryGetEntry(std::shared_ptr const&, DB::ConnectionTimeouts const&, String&, DB::Settings const&, DB::QualifiedTableName const*, std::function) @ 0x00000000332a525f 10. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:168: PoolWithFailoverBase::TryResult std::__function::__policy_invoker::TryResult (std::shared_ptr const&, String&)>::__call_impl::TryResult (std::shared_ptr const&, String&)>>(std::__function::__policy_storage const*, std::shared_ptr const&, String&) @ 0x00000000332a68e8 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x00000000332a7d40 12. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:223: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000332a45d2 13. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:170: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000332a4e02 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x000000003290e3d2 15. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:377: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x0000000032906db9 16. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000032906b09 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e722c80 18. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000295508e1 19. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 20. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.415698 [ 5753 ] {bd393622-4179-4244-aae1-b3fe8d2dca3a} TCPHandler: Code: 516. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 : While sending /var/lib/clickhouse/store/1ec/1ec9b2a5-961d-415d-8f79-a2b74cba15a2/default:foo@127%2E0%2E0%2E1:9000,default:foo@127%2E0%2E0%2E2:9000/1.bin. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:452: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x0000000033278953 6. ./build_docker/./src/Client/Connection.cpp:202: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003327463e 7. ./build_docker/./src/Client/Connection.cpp:512: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003327d0a6 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:44: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&) @ 0x000000003329673f 9. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:0: DB::ConnectionPoolWithFailover::tryGetEntry(std::shared_ptr const&, DB::ConnectionTimeouts const&, String&, DB::Settings const&, DB::QualifiedTableName const*, std::function) @ 0x00000000332a525f 10. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:168: PoolWithFailoverBase::TryResult std::__function::__policy_invoker::TryResult (std::shared_ptr const&, String&)>::__call_impl::TryResult (std::shared_ptr const&, String&)>>(std::__function::__policy_storage const*, std::shared_ptr const&, String&) @ 0x00000000332a68e8 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x00000000332a7d40 12. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:223: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000332a45d2 13. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:170: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000332a4e02 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x000000003290e3d2 15. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:377: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x0000000032906db9 16. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000032906b09 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e722c80 18. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000295508e1 19. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 20. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.423933 [ 48598 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:35.424191 [ 48598 ] {} ServerErrorHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:35.440560 [ 5753 ] {040381ee-cd73-4305-b5bc-5831f7f1d906} StorageDistributed (dist_01555): Cannot flush: Code: 516. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 : While sending /var/lib/clickhouse/store/1ec/1ec9b2a5-961d-415d-8f79-a2b74cba15a2/default:foo@127%2E0%2E0%2E1:9000,default:foo@127%2E0%2E0%2E2:9000/1.bin. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:452: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x0000000033278953 6. ./build_docker/./src/Client/Connection.cpp:202: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003327463e 7. ./build_docker/./src/Client/Connection.cpp:542: DB::Connection::forceConnected(DB::ConnectionTimeouts const&) @ 0x000000003327dc48 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:49: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&) @ 0x0000000033296b35 9. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:0: DB::ConnectionPoolWithFailover::tryGetEntry(std::shared_ptr const&, DB::ConnectionTimeouts const&, String&, DB::Settings const&, DB::QualifiedTableName const*, std::function) @ 0x00000000332a525f 10. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:168: PoolWithFailoverBase::TryResult std::__function::__policy_invoker::TryResult (std::shared_ptr const&, String&)>::__call_impl::TryResult (std::shared_ptr const&, String&)>>(std::__function::__policy_storage const*, std::shared_ptr const&, String&) @ 0x00000000332a68e8 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x00000000332a7d40 12. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:223: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000332a45d2 13. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:170: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000332a4e02 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x000000003290e3d2 15. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:0: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x0000000032906d57 16. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000032906b09 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e722c80 18. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000295508e1 19. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 20. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:35.453030 [ 48614 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:35.453261 [ 48614 ] {} ServerErrorHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:35.472741 [ 1278 ] {} test_9ol2pjvx.dist_01555.DistributedInsertQueue.default: Code: 516. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 : While sending /var/lib/clickhouse/store/0a1/0a1474cf-05f2-4ebf-9d8a-fc5826bfc682/default:foo@127%2E0%2E0%2E1:9000,default:foo@127%2E0%2E0%2E2:9000/1.bin. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:452: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x0000000033278953 6. ./build_docker/./src/Client/Connection.cpp:202: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003327463e 7. ./build_docker/./src/Client/Connection.cpp:512: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003327d0a6 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:44: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&) @ 0x000000003329673f 9. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:0: DB::ConnectionPoolWithFailover::tryGetEntry(std::shared_ptr const&, DB::ConnectionTimeouts const&, String&, DB::Settings const&, DB::QualifiedTableName const*, std::function) @ 0x00000000332a525f 10. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:168: PoolWithFailoverBase::TryResult std::__function::__policy_invoker::TryResult (std::shared_ptr const&, String&)>::__call_impl::TryResult (std::shared_ptr const&, String&)>>(std::__function::__policy_storage const*, std::shared_ptr const&, String&) @ 0x00000000332a68e8 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x00000000332a7d40 12. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:223: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000332a45d2 13. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:170: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000332a4e02 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x000000003290e3d2 15. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:377: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x0000000032906db9 16. ./contrib/llvm-project/libcxx/include/vector:580: DB::DistributedAsyncInsertDirectoryQueue::run() @ 0x0000000032907453 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f0fe371 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002f103012 19. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002f103e52 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:35.473873 [ 48598 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:35.474086 [ 48598 ] {} ServerErrorHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:35.474660 [ 5753 ] {6ab7fdc0-e5c3-4303-8f57-9938f75293f2} executeQuery: Code: 516. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 : While sending /var/lib/clickhouse/store/0a1/0a1474cf-05f2-4ebf-9d8a-fc5826bfc682/default:foo@127%2E0%2E0%2E1:9000,default:foo@127%2E0%2E0%2E2:9000/1.bin. (AUTHENTICATION_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:40462) (comment: 01555_system_distribution_queue_mask.sql) (in query: -- since test_cluster_with_incorrect_pw contains incorrect password ignore error system flush distributed dist_01555;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:452: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x0000000033278953 6. ./build_docker/./src/Client/Connection.cpp:202: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003327463e 7. ./build_docker/./src/Client/Connection.cpp:542: DB::Connection::forceConnected(DB::ConnectionTimeouts const&) @ 0x000000003327dc48 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:49: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&) @ 0x0000000033296b35 9. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:0: DB::ConnectionPoolWithFailover::tryGetEntry(std::shared_ptr const&, DB::ConnectionTimeouts const&, String&, DB::Settings const&, DB::QualifiedTableName const*, std::function) @ 0x00000000332a525f 10. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:168: PoolWithFailoverBase::TryResult std::__function::__policy_invoker::TryResult (std::shared_ptr const&, String&)>::__call_impl::TryResult (std::shared_ptr const&, String&)>>(std::__function::__policy_storage const*, std::shared_ptr const&, String&) @ 0x00000000332a68e8 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x00000000332a7d40 12. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:223: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000332a45d2 13. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:170: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000332a4e02 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x000000003290e3d2 15. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:0: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x0000000032906d57 16. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000032906b09 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e722c80 18. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000295508e1 19. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 20. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.474800 [ 5753 ] {6ab7fdc0-e5c3-4303-8f57-9938f75293f2} TCPHandler: Code: 516. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 : While sending /var/lib/clickhouse/store/0a1/0a1474cf-05f2-4ebf-9d8a-fc5826bfc682/default:foo@127%2E0%2E0%2E1:9000,default:foo@127%2E0%2E0%2E2:9000/1.bin. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:452: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x0000000033278953 6. ./build_docker/./src/Client/Connection.cpp:202: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003327463e 7. ./build_docker/./src/Client/Connection.cpp:542: DB::Connection::forceConnected(DB::ConnectionTimeouts const&) @ 0x000000003327dc48 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:49: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&) @ 0x0000000033296b35 9. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:0: DB::ConnectionPoolWithFailover::tryGetEntry(std::shared_ptr const&, DB::ConnectionTimeouts const&, String&, DB::Settings const&, DB::QualifiedTableName const*, std::function) @ 0x00000000332a525f 10. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:168: PoolWithFailoverBase::TryResult std::__function::__policy_invoker::TryResult (std::shared_ptr const&, String&)>::__call_impl::TryResult (std::shared_ptr const&, String&)>>(std::__function::__policy_storage const*, std::shared_ptr const&, String&) @ 0x00000000332a68e8 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x00000000332a7d40 12. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:223: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000332a45d2 13. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:170: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000332a4e02 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x000000003290e3d2 15. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:0: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x0000000032906d57 16. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000032906b09 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e722c80 18. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000295508e1 19. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 20. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.483598 [ 48598 ] {} Access(user directories): from: ::ffff:127.0.0.1, user: default: Authentication failed: Code: 193. DB::Exception: Invalid credentials. (WRONG_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Access/IAccessStorage.cpp:763: DB::IAccessStorage::throwInvalidCredentials() @ 0x000000002ee0330e 5. ./build_docker/./src/Access/IAccessStorage.cpp:539: DB::IAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee02f90 6. ./build_docker/./src/Access/IAccessStorage.cpp:511: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee028b7 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:451: DB::MultipleAccessStorage::authenticateImpl(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool, bool) const @ 0x000000002ee60381 8. ./build_docker/./src/Access/IAccessStorage.cpp:499: DB::IAccessStorage::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ExternalAuthenticators const&, bool, bool) const @ 0x000000002ee02799 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8875 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 11. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 13. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:35.483946 [ 48598 ] {} ServerErrorHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:35.484284 [ 5753 ] {ac260432-098e-4a7f-8d26-6ed7f7457a4e} StorageDistributed (dist_01555): Cannot flush: Code: 516. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000002ecd8f6d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&) @ 0x0000000031333c0c 6. ./src/Access/Credentials.h:51: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&) @ 0x000000003133324d 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x0000000033497f07 8. ./build_docker/./src/Server/TCPHandler.cpp:274: DB::TCPHandler::runImpl() @ 0x0000000033484476 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 : While sending /var/lib/clickhouse/store/0a1/0a1474cf-05f2-4ebf-9d8a-fc5826bfc682/default:foo@127%2E0%2E0%2E1:9000,default:foo@127%2E0%2E0%2E2:9000/1.bin. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:452: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x0000000033278953 6. ./build_docker/./src/Client/Connection.cpp:202: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003327463e 7. ./build_docker/./src/Client/Connection.cpp:542: DB::Connection::forceConnected(DB::ConnectionTimeouts const&) @ 0x000000003327dc48 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:49: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&) @ 0x0000000033296b35 9. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:0: DB::ConnectionPoolWithFailover::tryGetEntry(std::shared_ptr const&, DB::ConnectionTimeouts const&, String&, DB::Settings const&, DB::QualifiedTableName const*, std::function) @ 0x00000000332a525f 10. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:168: PoolWithFailoverBase::TryResult std::__function::__policy_invoker::TryResult (std::shared_ptr const&, String&)>::__call_impl::TryResult (std::shared_ptr const&, String&)>>(std::__function::__policy_storage const*, std::shared_ptr const&, String&) @ 0x00000000332a68e8 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x00000000332a7d40 12. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:223: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000332a45d2 13. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:170: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000332a4e02 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x000000003290e3d2 15. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:0: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x0000000032906d57 16. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000032906b09 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e722c80 18. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000295508e1 19. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 20. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 21. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:35.624874 [ 5753 ] {8f5e7120-9910-4884-9597-7c3d69cfa7d7} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 24.3.12.76.altinitystable) (from [::1]:40492) (comment: 01553_settings_early_apply.sql) (in query: select * from numbers(100) settings max_result_rows = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:51: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000033b7014d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.624993 [ 5753 ] {8f5e7120-9910-4884-9597-7c3d69cfa7d7} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:51: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000033b7014d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.628447 [ 5753 ] {6bcaf9e3-a1cc-4332-85ac-64db5268b977} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 24.3.12.76.altinitystable) (from [::1]:40492) (comment: 01553_settings_early_apply.sql) (in query: select * from numbers(100) FORMAT JSON settings max_result_rows = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:51: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000033b7014d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.628519 [ 5753 ] {6bcaf9e3-a1cc-4332-85ac-64db5268b977} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:51: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000033b7014d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.631012 [ 5753 ] {3137b1a9-5c0c-485d-8492-6e91a2d0f6d1} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 24.3.12.76.altinitystable) (from [::1]:40492) (comment: 01553_settings_early_apply.sql) (in query: select * from numbers(100) FORMAT TSVWithNamesAndTypes settings max_result_rows = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:51: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000033b7014d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.631084 [ 5753 ] {3137b1a9-5c0c-485d-8492-6e91a2d0f6d1} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:51: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000033b7014d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.633781 [ 5753 ] {49931a99-214c-449d-8404-ea198541c1b1} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 24.3.12.76.altinitystable) (from [::1]:40492) (comment: 01553_settings_early_apply.sql) (in query: select * from numbers(100) FORMAT CSVWithNamesAndTypes settings max_result_rows = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:51: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000033b7014d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.633873 [ 5753 ] {49931a99-214c-449d-8404-ea198541c1b1} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:51: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000033b7014d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.636711 [ 5753 ] {f446ca36-566b-424d-9862-711d26759a31} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 24.3.12.76.altinitystable) (from [::1]:40492) (comment: 01553_settings_early_apply.sql) (in query: select * from numbers(100) FORMAT JSONCompactEachRowWithNamesAndTypes settings max_result_rows = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:51: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000033b7014d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.636789 [ 5753 ] {f446ca36-566b-424d-9862-711d26759a31} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:51: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000033b7014d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.639021 [ 5753 ] {0809f9ba-0381-40cd-b8cd-f36922e1bcd5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 24.3.12.76.altinitystable) (from [::1]:40492) (comment: 01553_settings_early_apply.sql) (in query: select * from numbers(100) FORMAT XML settings max_result_rows = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:51: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000033b7014d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.639092 [ 5753 ] {0809f9ba-0381-40cd-b8cd-f36922e1bcd5} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:51: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000033b7014d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.642218 [ 5753 ] {9b1c5916-36f1-413e-bc1a-ab361436d2f8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 10.00. (TOO_MANY_ROWS_OR_BYTES) (version 24.3.12.76.altinitystable) (from [::1]:40492) (comment: 01553_settings_early_apply.sql) (in query: select * from numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:51: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000033b7014d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.642280 [ 5753 ] {9b1c5916-36f1-413e-bc1a-ab361436d2f8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 10.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:51: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000033b7014d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.807186 [ 5753 ] {a959a316-30dc-44a8-bdda-8fe5f9cf18b6} executeQuery: Code: 50. DB::Exception: Unknown data type family: CODEC. (UNKNOWN_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:40546) (comment: 01559_misplaced_codec_diagnostics.sh) (in query: CREATE TABLE t (c CODEC(NONE)) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:266: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x000000002f47e8b1 5. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:144: std::shared_ptr DB::DataTypeFactory::getImpl(String const&, std::shared_ptr const&) const @ 0x000000002f47c91b 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b10d8 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:35.807586 [ 5753 ] {a959a316-30dc-44a8-bdda-8fe5f9cf18b6} TCPHandler: Code: 50. DB::Exception: Unknown data type family: CODEC. (UNKNOWN_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:266: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x000000002f47e8b1 5. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:144: std::shared_ptr DB::DataTypeFactory::getImpl(String const&, std::shared_ptr const&) const @ 0x000000002f47c91b 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b10d8 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:36.275593 [ 5753 ] {176bc796-2ccf-4c92-ab37-47b9083afb67} executeQuery: Code: 27. DB::Exception: Cannot read input: expected a digit but got something else: In scope SELECT toModifiedJulianDay('unparsable'). (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:40614) (comment: 01543_toModifiedJulianDay.sql) (in query: SELECT toModifiedJulianDay('unparsable');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::readDigit(DB::ReadBuffer&) @ 0x00000000193ed8b6 5. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x00000000193ed43f 6. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021a6130e 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:36.275795 [ 5753 ] {176bc796-2ccf-4c92-ab37-47b9083afb67} TCPHandler: Code: 27. DB::Exception: Cannot read input: expected a digit but got something else: In scope SELECT toModifiedJulianDay('unparsable'). (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::readDigit(DB::ReadBuffer&) @ 0x00000000193ed8b6 5. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x00000000193ed43f 6. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021a6130e 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:14:36.305442 [ 5753 ] {4a105a0d-5423-488d-9181-092f73dae8e2} executeQuery: Code: 38. DB::Exception: Invalid date, out of range (year: 1999, month: 2, day_of_month: 29).: In scope SELECT toModifiedJulianDay('1999-02-29'). (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:40614) (comment: 01543_toModifiedJulianDay.sql) (in query: SELECT toModifiedJulianDay('1999-02-29');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x00000000193efa89 4. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x00000000193ed60a 5. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021a6130e 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:14:36.305622 [ 5753 ] {4a105a0d-5423-488d-9181-092f73dae8e2} TCPHandler: Code: 38. DB::Exception: Invalid date, out of range (year: 1999, month: 2, day_of_month: 29).: In scope SELECT toModifiedJulianDay('1999-02-29'). (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x00000000193efa89 4. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x00000000193ed60a 5. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021a6130e 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:14:36.307439 [ 5753 ] {e092fdb2-f0e1-42fc-bbbb-f1059b5a91af} executeQuery: Code: 38. DB::Exception: Invalid date, out of range (year: 1999, month: 13, day_of_month: 32).: In scope SELECT toModifiedJulianDay('1999-13-32'). (CANNOT_PARSE_DATE) (version 24.3.12.76.altinitystable) (from [::1]:40614) (comment: 01543_toModifiedJulianDay.sql) (in query: SELECT toModifiedJulianDay('1999-13-32');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x00000000193efa89 4. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x00000000193ed60a 5. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021a6130e 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:14:36.307584 [ 5753 ] {e092fdb2-f0e1-42fc-bbbb-f1059b5a91af} TCPHandler: Code: 38. DB::Exception: Invalid date, out of range (year: 1999, month: 13, day_of_month: 32).: In scope SELECT toModifiedJulianDay('1999-13-32'). (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x00000000193efa89 4. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x00000000193ed60a 5. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021a6130e 6. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:14:36.767786 [ 5753 ] {8543cfcd-f793-45ba-9712-ed47d4bf6dc2} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while executing 'FUNCTION CAST(arrayJoin(_CAST([NULL, '', '', NULL, '', NULL, '01.02.2017 03:04\005GMT', '', NULL, '01/02/2017 03:04:05 MSK01/02/\0017 03:04:05 MSK', '', NULL, '03/04/201903/04/201903/04/\001903/04/2019']_Array(Nullable(String)), 'Array(Nullable(String))'_String)) :: 3, 'Enum8(\'a\' = 1, \'b\' = 2)'_String :: 2) -> CAST(arrayJoin(_CAST([NULL, '', '', NULL, '', NULL, '01.02.2017 03:04\005GMT', '', NULL, '01/02/2017 03:04:05 MSK01/02/\0017 03:04:05 MSK', '', NULL, '03/04/201903/04/201903/04/\001903/04/2019']_Array(Nullable(String)), 'Array(Nullable(String))'_String)), 'Enum8(\'a\' = 1, \'b\' = 2)'_String) Enum8('a' = 1, 'b' = 2) : 1'. (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:40682) (comment: 01536_fuzz_cast.sql) (in query: SELECT CAST(arrayJoin([NULL, '', '', NULL, '', NULL, '01.02.2017 03:04\005GMT', '', NULL, '01/02/2017 03:04:05 MSK01/02/\0017 03:04:05 MSK', '', NULL, '03/04/201903/04/201903/04/\001903/04/2019']), 'Enum8(\'a\' = 1, \'b\' = 2)') AS x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000185cb3ee 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:36.767964 [ 5753 ] {8543cfcd-f793-45ba-9712-ed47d4bf6dc2} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while executing 'FUNCTION CAST(arrayJoin(_CAST([NULL, '', '', NULL, '', NULL, '01.02.2017 03:04\005GMT', '', NULL, '01/02/2017 03:04:05 MSK01/02/\0017 03:04:05 MSK', '', NULL, '03/04/201903/04/201903/04/\001903/04/2019']_Array(Nullable(String)), 'Array(Nullable(String))'_String)) :: 3, 'Enum8(\'a\' = 1, \'b\' = 2)'_String :: 2) -> CAST(arrayJoin(_CAST([NULL, '', '', NULL, '', NULL, '01.02.2017 03:04\005GMT', '', NULL, '01/02/2017 03:04:05 MSK01/02/\0017 03:04:05 MSK', '', NULL, '03/04/201903/04/201903/04/\001903/04/2019']_Array(Nullable(String)), 'Array(Nullable(String))'_String)), 'Enum8(\'a\' = 1, \'b\' = 2)'_String) Enum8('a' = 1, 'b' = 2) : 1'. (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000185cb3ee 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.553853 [ 5753 ] {895582a7-1484-4dfa-8d8f-64bbec522bcb} executeQuery: Code: 6. DB::Exception: Cannot parse force_data_skipping_indices (''). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:46872) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 SETTINGS force_data_skipping_indices='';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:612: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a862 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.554126 [ 5753 ] {895582a7-1484-4dfa-8d8f-64bbec522bcb} TCPHandler: Code: 6. DB::Exception: Cannot parse force_data_skipping_indices (''). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:612: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a862 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.557012 [ 5753 ] {6ab6aa3c-6366-4251-ac11-eb4cc33554db} executeQuery: Code: 277. DB::Exception: Index `d1_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:46872) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 SETTINGS force_data_skipping_indices='d1_idx';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.557152 [ 5753 ] {6ab6aa3c-6366-4251-ac11-eb4cc33554db} TCPHandler: Code: 277. DB::Exception: Index `d1_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.559029 [ 5753 ] {39a528ad-57bd-4675-ae72-fb98b8917af7} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:46872) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 SETTINGS force_data_skipping_indices='d1_null_idx';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.559137 [ 5753 ] {39a528ad-57bd-4675-ae72-fb98b8917af7} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.576161 [ 5753 ] {5448c4a8-caae-4093-b29f-86178d07e4cf} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:46872) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices='d1_idx,d1_null_idx';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.576275 [ 5753 ] {5448c4a8-caae-4093-b29f-86178d07e4cf} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.578576 [ 5753 ] {0c6860c6-601c-4c45-8207-c99bb26d152a} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:46872) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices='d1_null_idx,d1_idx';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.578684 [ 5753 ] {0c6860c6-601c-4c45-8207-c99bb26d152a} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.580909 [ 5753 ] {531f7f78-91c5-41f1-90f8-35ff5d697720} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:46872) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices='d1_null_idx,d1_idx,,';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.581011 [ 5753 ] {531f7f78-91c5-41f1-90f8-35ff5d697720} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.583101 [ 5753 ] {7a40fa7d-cd8d-4804-8305-29e90b0e68f2} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:46872) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices=' d1_null_idx,d1_idx';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.583203 [ 5753 ] {7a40fa7d-cd8d-4804-8305-29e90b0e68f2} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.585321 [ 5753 ] {9e9455e6-5a99-4ab8-a81c-21e5aac2af0d} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:46872) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices=' `d1_null_idx`,d1_idx';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.585450 [ 5753 ] {9e9455e6-5a99-4ab8-a81c-21e5aac2af0d} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.587746 [ 5753 ] {605fb87a-f76d-4190-9599-5f006a8691ba} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:46872) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices='d1_null_idx';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.587859 [ 5753 ] {605fb87a-f76d-4190-9599-5f006a8691ba} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.590038 [ 5753 ] {df2c6a7b-4f6e-4c82-8f93-4874bff18536} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:46872) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices=' d1_null_idx ';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.590139 [ 5753 ] {df2c6a7b-4f6e-4c82-8f93-4874bff18536} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.592404 [ 5753 ] {e40ddba4-7e03-483d-b7d7-4236c0ea0841} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.3.12.76.altinitystable) (from [::1]:46872) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 WHERE d1_null = 0 SETTINGS force_data_skipping_indices='d1_null_idx';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:39.592540 [ 5753 ] {e40ddba4-7e03-483d-b7d7-4236c0ea0841} TCPHandler: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool) @ 0x0000000032c9a67d 5. ./contrib/llvm-project/libcxx/include/vector:951: DB::ReadFromMergeTree::selectRangesToReadImpl(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f40f26 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&) @ 0x0000000033f3c94a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1371: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::vector, std::allocator>>) const @ 0x0000000033f3c31a 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1854: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x0000000033f465a3 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f493e4 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:40.923362 [ 48602 ] {f89b6384-0b37-47a9-b60e-73a3b3b366e7} executeQuery: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS) (version 24.3.12.76.altinitystable) (from [::1]:47280) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: INSERT INTO r1 VALUES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000030711d29 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:215: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000033031114 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003302e918 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000033014cec 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x000000003301139e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 14. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:40.923578 [ 48602 ] {f89b6384-0b37-47a9-b60e-73a3b3b366e7} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000030711d29 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:215: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000033031114 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003302e918 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000033014cec 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x000000003301139e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 14. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:40.928542 [ 48602 ] {f4be6931-4561-46f6-b31e-35cdd9b48bfd} executeQuery: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS) (version 24.3.12.76.altinitystable) (from [::1]:47280) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: -- retry should still fail despite the insert_deduplicate enabled INSERT INTO r1 VALUES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000030711d29 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:215: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000033031114 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003302e918 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000033014cec 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x000000003301139e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 14. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:40.928685 [ 48602 ] {f4be6931-4561-46f6-b31e-35cdd9b48bfd} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000030711d29 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:215: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000033031114 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003302e918 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000033014cec 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x000000003301139e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 14. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:40.932416 [ 48602 ] {6b9ccc51-475c-4bd6-a535-f4bcae6bf0a5} executeQuery: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS) (version 24.3.12.76.altinitystable) (from [::1]:47280) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: INSERT INTO r1 VALUES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000030711d29 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:215: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000033031114 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003302e918 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000033014cec 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x000000003301139e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 14. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:40.932600 [ 48602 ] {6b9ccc51-475c-4bd6-a535-f4bcae6bf0a5} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000030711d29 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:215: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000033031114 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003302e918 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000033014cec 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x000000003301139e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 14. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:40.976529 [ 48602 ] {c5969941-8338-4aa2-aea3-07557c29e17a} executeQuery: Code: 285. DB::Exception: Number of alive replicas (1) is less than requested quorum (2/2). (TOO_FEW_LIVE_REPLICAS) (version 24.3.12.76.altinitystable) (from [::1]:47280) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: INSERT INTO r1 VALUES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000030711d29 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:215: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000033031114 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003302e918 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000033014cec 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x000000003301139e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 14. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:40.976679 [ 48602 ] {c5969941-8338-4aa2-aea3-07557c29e17a} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (1) is less than requested quorum (2/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000030711d29 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:215: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000033031114 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003302e918 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000033014cec 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x000000003301139e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 14. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:40.980008 [ 48602 ] {c507463b-2d23-4397-91ea-e4c4409b3cbd} executeQuery: Code: 285. DB::Exception: Number of alive replicas (1) is less than requested quorum (2/2). (TOO_FEW_LIVE_REPLICAS) (version 24.3.12.76.altinitystable) (from [::1]:47280) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: -- retry should fail despite the insert_deduplicate enabled INSERT INTO r1 VALUES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000030711d29 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:215: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000033031114 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003302e918 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000033014cec 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x000000003301139e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 14. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:40.980384 [ 48602 ] {c507463b-2d23-4397-91ea-e4c4409b3cbd} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (1) is less than requested quorum (2/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000030711d29 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:215: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000033031114 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003302e918 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000033014cec 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x000000003301139e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 14. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:40.983499 [ 48602 ] {3e754b71-b026-404a-87b4-b06b54387084} executeQuery: Code: 285. DB::Exception: Number of alive replicas (1) is less than requested quorum (2/2). (TOO_FEW_LIVE_REPLICAS) (version 24.3.12.76.altinitystable) (from [::1]:47280) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: INSERT INTO r1 VALUES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000030711d29 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:215: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000033031114 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003302e918 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000033014cec 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x000000003301139e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 14. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:40.983624 [ 48602 ] {3e754b71-b026-404a-87b4-b06b54387084} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (1) is less than requested quorum (2/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000030711d29 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:215: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000033031114 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003302e918 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000033014cec 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x000000003301139e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 14. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:41.078565 [ 48602 ] {bc8f7048-e53a-4a8e-acbe-40c3eaa81b42} executeQuery: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS) (version 24.3.12.76.altinitystable) (from [::1]:47280) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: INSERT INTO r1 VALUES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000030711d29 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:215: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000033031114 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003302e918 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000033014cec 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x000000003301139e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 14. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:41.078702 [ 48602 ] {bc8f7048-e53a-4a8e-acbe-40c3eaa81b42} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000030711d29 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:215: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x0000000033031114 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000003302e918 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:250: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x0000000033014cec 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x000000003301139e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 14. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:41.111364 [ 48602 ] {e024a648-04a9-46ec-826f-c723e4841acc} executeQuery: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT) (version 24.3.12.76.altinitystable) (from [::1]:47280) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: INSERT INTO r1 SETTINGS insert_keeper_fault_injection_probability=0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1189: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x00000000330196f2 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1135: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()::operator()() const @ 0x000000003303e7ed 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003303e2f8 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033016690 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033013e19 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 16. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:41.111616 [ 48602 ] {e024a648-04a9-46ec-826f-c723e4841acc} TCPHandler: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1189: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x00000000330196f2 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1135: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()::operator()() const @ 0x000000003303e7ed 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003303e2f8 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033016690 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033013e19 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 16. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:41.121828 [ 48602 ] {d461de8a-18de-4ab7-a818-0c8f61be4ca8} executeQuery: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT) (version 24.3.12.76.altinitystable) (from [::1]:47280) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: -- retry should fail despite the insert_deduplicate enabled INSERT INTO r1 SETTINGS insert_keeper_fault_injection_probability=0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1189: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x00000000330196f2 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1135: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()::operator()() const @ 0x000000003303e7ed 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003303e2f8 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033016690 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033013e19 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 16. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:41.122362 [ 48602 ] {d461de8a-18de-4ab7-a818-0c8f61be4ca8} TCPHandler: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1189: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x00000000330196f2 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1135: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()::operator()() const @ 0x000000003303e7ed 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003303e2f8 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033016690 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033013e19 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 16. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:41.132884 [ 48602 ] {2f771fb9-64b9-4c96-8966-7f56d45e5925} executeQuery: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT) (version 24.3.12.76.altinitystable) (from [::1]:47280) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: INSERT INTO r1 SETTINGS insert_keeper_fault_injection_probability=0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1189: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x00000000330196f2 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1135: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()::operator()() const @ 0x000000003303e7ed 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003303e2f8 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033016690 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033013e19 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 16. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:41.133474 [ 48602 ] {2f771fb9-64b9-4c96-8966-7f56d45e5925} TCPHandler: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1189: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x00000000330196f2 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1135: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()::operator()() const @ 0x000000003303e7ed 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003303e2f8 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033016690 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033013e19 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 16. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:41.980100 [ 48606 ] {410a512d-7eb7-4f03-8db7-086cd334dfab} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 1.02 GiB (attempt to allocate chunk of 134218016 bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:57422) (comment: 01514_distributed_cancel_query_on_error.sh) (in query: SELECT groupArray(repeat('a', if(shardNum() = 2, 100000, 1))) AS `groupArray(repeat('a', if(equals(_shard_num, 2), 100000, 1)))`, `__table1`.`number` % 100000 AS `k` FROM `system`.`numbers` AS `__table1` GROUP BY `__table1`.`number` % 100000 LIMIT _CAST(10000000, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. DB::Arena::MemoryChunk::MemoryChunk(unsigned long) @ 0x000000001970ee91 9. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000001970ec28 10. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000001970ebc8 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:435: DB::(anonymous namespace)::GroupArrayNodeString::allocate(DB::IColumn const&, unsigned long, DB::Arena*) @ 0x000000002574d1dd 12. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:550: DB::(anonymous namespace)::GroupArrayGeneralImpl>::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x00000000257a2049 13. ./src/AggregateFunctions/IAggregateFunction.h:0: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000257a38b8 14. ./build_docker/./src/Interpreters/Aggregator.cpp:1380: DB::Aggregator::addBatch(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char**, DB::Arena*) @ 0x000000002fe5ead4 15. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x000000002fe5df78 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1228: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003005ac95 17. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000030055cc6 18. ./build_docker/./src/Interpreters/Aggregator.cpp:990: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002fef53e9 19. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002fe5af09 20. ./build_docker/./src/Interpreters/Aggregator.cpp:1626: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe6411b 21. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 22. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:42.052744 [ 48606 ] {410a512d-7eb7-4f03-8db7-086cd334dfab} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 1.02 GiB (attempt to allocate chunk of 134218016 bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. DB::Arena::MemoryChunk::MemoryChunk(unsigned long) @ 0x000000001970ee91 9. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000001970ec28 10. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000001970ebc8 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:435: DB::(anonymous namespace)::GroupArrayNodeString::allocate(DB::IColumn const&, unsigned long, DB::Arena*) @ 0x000000002574d1dd 12. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:550: DB::(anonymous namespace)::GroupArrayGeneralImpl>::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x00000000257a2049 13. ./src/AggregateFunctions/IAggregateFunction.h:0: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000257a38b8 14. ./build_docker/./src/Interpreters/Aggregator.cpp:1380: DB::Aggregator::addBatch(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char**, DB::Arena*) @ 0x000000002fe5ead4 15. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x000000002fe5df78 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1228: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003005ac95 17. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000030055cc6 18. ./build_docker/./src/Interpreters/Aggregator.cpp:990: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002fef53e9 19. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002fe5af09 20. ./build_docker/./src/Interpreters/Aggregator.cpp:1626: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe6411b 21. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 22. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:42.149251 [ 48605 ] {64ff56b9-dbff-44ae-9ce7-d54e383fe529} executeQuery: Code: 241. DB::Exception: Received from 127.3:9000. DB::Exception: Memory limit (for query) exceeded: would use 1.02 GiB (attempt to allocate chunk of 134218016 bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. DB::Arena::MemoryChunk::MemoryChunk(unsigned long) @ 0x000000001970ee91 9. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000001970ec28 10. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000001970ebc8 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:435: DB::(anonymous namespace)::GroupArrayNodeString::allocate(DB::IColumn const&, unsigned long, DB::Arena*) @ 0x000000002574d1dd 12. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:550: DB::(anonymous namespace)::GroupArrayGeneralImpl>::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x00000000257a2049 13. ./src/AggregateFunctions/IAggregateFunction.h:0: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000257a38b8 14. ./build_docker/./src/Interpreters/Aggregator.cpp:1380: DB::Aggregator::addBatch(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char**, DB::Arena*) @ 0x000000002fe5ead4 15. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x000000002fe5df78 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1228: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003005ac95 17. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000030055cc6 18. ./build_docker/./src/Interpreters/Aggregator.cpp:990: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002fef53e9 19. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002fe5af09 20. ./build_docker/./src/Interpreters/Aggregator.cpp:1626: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe6411b 21. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 22. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:47334) (comment: 01514_distributed_cancel_query_on_error.sh) (in query: SELECT groupArray(repeat('a', if(_shard_num == 2, 100000, 1))), number%100000 k from remote('127.{2,3}', system.numbers) GROUP BY k LIMIT 10e6), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:14:42.150972 [ 48605 ] {64ff56b9-dbff-44ae-9ce7-d54e383fe529} TCPHandler: Code: 241. DB::Exception: Received from 127.3:9000. DB::Exception: Memory limit (for query) exceeded: would use 1.02 GiB (attempt to allocate chunk of 134218016 bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. DB::Arena::MemoryChunk::MemoryChunk(unsigned long) @ 0x000000001970ee91 9. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000001970ec28 10. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000001970ebc8 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:435: DB::(anonymous namespace)::GroupArrayNodeString::allocate(DB::IColumn const&, unsigned long, DB::Arena*) @ 0x000000002574d1dd 12. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:550: DB::(anonymous namespace)::GroupArrayGeneralImpl>::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x00000000257a2049 13. ./src/AggregateFunctions/IAggregateFunction.h:0: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000257a38b8 14. ./build_docker/./src/Interpreters/Aggregator.cpp:1380: DB::Aggregator::addBatch(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char**, DB::Arena*) @ 0x000000002fe5ead4 15. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x000000002fe5df78 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1228: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003005ac95 17. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000030055cc6 18. ./build_docker/./src/Interpreters/Aggregator.cpp:990: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002fef53e9 19. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002fe5af09 20. ./build_docker/./src/Interpreters/Aggregator.cpp:1626: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002fe6411b 21. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000033e4c2b6 22. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x0000000033e45293 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:14:42.261309 [ 23628 ] {ee2a867f-f77a-4d86-94e5-216758b29c53} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:41922). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:41922) (comment: 01514_distributed_cancel_query_on_error.sh) (in query: SELECT groupArray(repeat('a', if(shardNum() = 2, 100000, 1))) AS `groupArray(repeat('a', if(equals(_shard_num, 2), 100000, 1)))`, `__table1`.`number` % 100000 AS `k` FROM `system`.`numbers` AS `__table1` GROUP BY `__table1`.`number` % 100000 LIMIT _CAST(10000000, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5be4 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:42.268282 [ 23628 ] {ee2a867f-f77a-4d86-94e5-216758b29c53} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:41922). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:42.268343 [ 23628 ] {ee2a867f-f77a-4d86-94e5-216758b29c53} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:41922). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2240: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aaf46 7. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5be4 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:42.268469 [ 23628 ] {ee2a867f-f77a-4d86-94e5-216758b29c53} TCPHandler: Client has gone away. 2025.03.05 21:14:43.270972 [ 48599 ] {cdaec6cb-5ce7-4503-bbec-984666dd3b4e} executeQuery: Code: 36. DB::Exception: Codec Delta is not applicable for String because the data type is not of fixed size. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:47776) (comment: 01504_compression_multiple_streams.sql) (in query: -- validation still works, non-sense codecs checked CREATE TABLE columns_with_multiple_streams_bad_case ( field0 Nullable(String) CODEC(Delta, LZ4) ) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Compression/CompressionCodecDelta.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000002f39e746 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./contrib/llvm-project/libcxx/include/vector:1613: DB::SerializationNullable::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f62eea1 8. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:43.271202 [ 48599 ] {cdaec6cb-5ce7-4503-bbec-984666dd3b4e} TCPHandler: Code: 36. DB::Exception: Codec Delta is not applicable for String because the data type is not of fixed size. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Compression/CompressionCodecDelta.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000002f39e746 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./contrib/llvm-project/libcxx/include/vector:1613: DB::SerializationNullable::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f62eea1 8. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:43.303667 [ 48599 ] {95cbaa29-0ee9-4803-98ab-f05ef0308e9c} executeQuery: Code: 431. DB::Exception: T64 codec is not supported for specified type String. (ILLEGAL_SYNTAX_FOR_CODEC_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:47776) (comment: 01504_compression_multiple_streams.sql) (in query: CREATE TABLE columns_with_multiple_streams_bad_case ( field0 Tuple(Array(UInt64), String) CODEC(T64, LZ4) ) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Compression/CompressionCodecT64.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000002f3b1687 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./contrib/llvm-project/libcxx/include/vector:1613: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f62b35f 8. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:641: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f6a2a34 9. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:43.303854 [ 48599 ] {95cbaa29-0ee9-4803-98ab-f05ef0308e9c} TCPHandler: Code: 431. DB::Exception: T64 codec is not supported for specified type String. (ILLEGAL_SYNTAX_FOR_CODEC_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Compression/CompressionCodecT64.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000002f3b1687 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./contrib/llvm-project/libcxx/include/vector:1613: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f62b35f 8. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:641: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f6a2a34 9. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.156629 [ 22858 ] {e318845e-a793-4a2d-949f-b71e55122f83} executeQuery: Code: 60. DB::Exception: Table test_pmiaicjp.t2 does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48680) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.156974 [ 22858 ] {e318845e-a793-4a2d-949f-b71e55122f83} TCPHandler: Code: 60. DB::Exception: Table test_pmiaicjp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.229561 [ 23597 ] {d208a015-2889-454c-88c1-09b041f8e3fd} executeQuery: Code: 60. DB::Exception: Table `test_pmiaicjp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48694) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:0: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002f7d7721 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:249: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f73f83c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f47348 7. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.229775 [ 23597 ] {d208a015-2889-454c-88c1-09b041f8e3fd} TCPHandler: Code: 60. DB::Exception: Table `test_pmiaicjp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:0: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002f7d7721 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:249: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f73f83c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f47348 7. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.247874 [ 730 ] {b4301093-f63e-4751-86db-9f0cdc43e923} executeQuery: Code: 60. DB::Exception: Table `test_pmiaicjp`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48704) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:0: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002f7d7721 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:249: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f73f83c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f47348 7. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.248050 [ 730 ] {b4301093-f63e-4751-86db-9f0cdc43e923} TCPHandler: Code: 60. DB::Exception: Table `test_pmiaicjp`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:0: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002f7d7721 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:249: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f73f83c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f47348 7. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.303264 [ 22858 ] {eba296bc-4705-4598-b8a2-e4560e6105c4} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48730) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.303557 [ 22858 ] {eba296bc-4705-4598-b8a2-e4560e6105c4} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.339354 [ 12525 ] {07c32f49-80db-42a0-a06c-39a6ca551255} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:48558). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:48558) (in query: SELECT DISTINCT arrayJoin(extractAll(name, '[\\w_]{2,}')) AS res FROM (SELECT * FROM viewIfPermitted(SELECT name FROM system.functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_engines ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.formats ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.data_type_families ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.merge_tree_settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT cluster FROM system.clusters ELSE null('cluster String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT macro FROM system.macros ELSE null('macro String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT policy_name FROM system.storage_policies ELSE null('policy_name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT concat(func.name, comb.name) AS x FROM system.functions AS func CROSS JOIN system.aggregate_function_combinators AS comb WHERE is_aggregate ELSE null('x String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.databases LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.tables LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.dictionaries LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.columns LIMIT 10000 ELSE null('name String'))) WHERE notEmpty(res)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2301: DB::TCPHandler::sendProgress() @ 0x00000000334a63fb 7. ./contrib/llvm-project/libcxx/include/__mutex_base:143: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5cbd 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.339379 [ 23597 ] {20c7fc13-9580-4768-b8a7-e78c6b15f811} executeQuery: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48716) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.339770 [ 23597 ] {20c7fc13-9580-4768-b8a7-e78c6b15f811} TCPHandler: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.342278 [ 48624 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::1]:48564). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:45.347768 [ 12525 ] {07c32f49-80db-42a0-a06c-39a6ca551255} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:48558). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2301: DB::TCPHandler::sendProgress() @ 0x00000000334a63fb 7. ./contrib/llvm-project/libcxx/include/__mutex_base:143: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a5cbd 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.348019 [ 12525 ] {07c32f49-80db-42a0-a06c-39a6ca551255} TCPHandler: Client has gone away. 2025.03.05 21:14:45.348768 [ 3522 ] {bc9b2ba5-848d-4865-84d7-8da1de1e4a17} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48750) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.349177 [ 3522 ] {bc9b2ba5-848d-4865-84d7-8da1de1e4a17} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.371181 [ 23622 ] {c6e1f027-acc7-46b7-bb95-15f9ff9f9056} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:48648). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:48648) (in query: SELECT DISTINCT arrayJoin(extractAll(name, '[\\w_]{2,}')) AS res FROM (SELECT * FROM viewIfPermitted(SELECT name FROM system.functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_engines ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.formats ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.data_type_families ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.merge_tree_settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT cluster FROM system.clusters ELSE null('cluster String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT macro FROM system.macros ELSE null('macro String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT policy_name FROM system.storage_policies ELSE null('policy_name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT concat(func.name, comb.name) AS x FROM system.functions AS func CROSS JOIN system.aggregate_function_combinators AS comb WHERE is_aggregate ELSE null('x String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.databases LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.tables LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.dictionaries LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.columns LIMIT 10000 ELSE null('name String'))) WHERE notEmpty(res)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2217: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aae9a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.377737 [ 23622 ] {c6e1f027-acc7-46b7-bb95-15f9ff9f9056} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:48648). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882aaf 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2217: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aae9a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.377898 [ 23622 ] {c6e1f027-acc7-46b7-bb95-15f9ff9f9056} TCPHandler: Client has gone away. 2025.03.05 21:14:45.408397 [ 22858 ] {d28e9810-1768-47ce-9bc4-018fec05132d} executeQuery: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. Maybe you meant test_pmiaicjp.t2?. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48764) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.425257 [ 22858 ] {d28e9810-1768-47ce-9bc4-018fec05132d} TCPHandler: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. Maybe you meant test_pmiaicjp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.425377 [ 23622 ] {7bad65fa-f8f9-477b-b62b-378d94d6c31c} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48780) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000030f36f0f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.441718 [ 48581 ] {79b73ef9-b708-4941-9e85-8232f93617b9} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:48622). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:48622) (in query: SELECT DISTINCT arrayJoin(extractAll(name, '[\\w_]{2,}')) AS res FROM (SELECT * FROM viewIfPermitted(SELECT name FROM system.functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_engines ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.formats ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.data_type_families ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.merge_tree_settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT cluster FROM system.clusters ELSE null('cluster String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT macro FROM system.macros ELSE null('macro String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT policy_name FROM system.storage_policies ELSE null('policy_name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT concat(func.name, comb.name) AS x FROM system.functions AS func CROSS JOIN system.aggregate_function_combinators AS comb WHERE is_aggregate ELSE null('x String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.databases LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.tables LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.dictionaries LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.columns LIMIT 10000 ELSE null('name String'))) WHERE notEmpty(res)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2217: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aae9a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.441867 [ 10241 ] {52f24f81-af93-4b89-bd98-d72d5bd67d72} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:48588). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:48588) (in query: SELECT DISTINCT arrayJoin(extractAll(name, '[\\w_]{2,}')) AS res FROM (SELECT * FROM viewIfPermitted(SELECT name FROM system.functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_engines ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.formats ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.data_type_families ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.merge_tree_settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT cluster FROM system.clusters ELSE null('cluster String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT macro FROM system.macros ELSE null('macro String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT policy_name FROM system.storage_policies ELSE null('policy_name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT concat(func.name, comb.name) AS x FROM system.functions AS func CROSS JOIN system.aggregate_function_combinators AS comb WHERE is_aggregate ELSE null('x String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.databases LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.tables LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.dictionaries LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.columns LIMIT 10000 ELSE null('name String'))) WHERE notEmpty(res)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2217: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aae9a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.446752 [ 23622 ] {7bad65fa-f8f9-477b-b62b-378d94d6c31c} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000030f36f0f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.457472 [ 14974 ] {1d692725-2851-4a58-9550-1d11a7ad7de6} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:48640). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:48640) (in query: SELECT DISTINCT arrayJoin(extractAll(name, '[\\w_]{2,}')) AS res FROM (SELECT * FROM viewIfPermitted(SELECT name FROM system.functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_engines ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.formats ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.data_type_families ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.merge_tree_settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT cluster FROM system.clusters ELSE null('cluster String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT macro FROM system.macros ELSE null('macro String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT policy_name FROM system.storage_policies ELSE null('policy_name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT concat(func.name, comb.name) AS x FROM system.functions AS func CROSS JOIN system.aggregate_function_combinators AS comb WHERE is_aggregate ELSE null('x String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.databases LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.tables LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.dictionaries LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.columns LIMIT 10000 ELSE null('name String'))) WHERE notEmpty(res)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2217: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aae9a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.465120 [ 10241 ] {52f24f81-af93-4b89-bd98-d72d5bd67d72} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:48588). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2217: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aae9a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.465297 [ 10241 ] {52f24f81-af93-4b89-bd98-d72d5bd67d72} TCPHandler: Client has gone away. 2025.03.05 21:14:45.467316 [ 14974 ] {1d692725-2851-4a58-9550-1d11a7ad7de6} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:48640). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2217: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aae9a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.467438 [ 14974 ] {1d692725-2851-4a58-9550-1d11a7ad7de6} TCPHandler: Client has gone away. 2025.03.05 21:14:45.471353 [ 48581 ] {79b73ef9-b708-4941-9e85-8232f93617b9} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:48622). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./build_docker/./src/Server/TCPHandler.cpp:2217: DB::TCPHandler::sendData(DB::Block const&) @ 0x00000000334aae9a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x00000000334a57b7 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003348725d 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.471555 [ 48581 ] {79b73ef9-b708-4941-9e85-8232f93617b9} TCPHandler: Client has gone away. 2025.03.05 21:14:45.532016 [ 23622 ] {de2ec45d-16de-4461-8bc3-772164cdec0e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48850) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.532174 [ 23622 ] {de2ec45d-16de-4461-8bc3-772164cdec0e} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.725060 [ 23597 ] {02ae1867-d781-4b88-b3ee-c9f8f697098b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48936) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000030f36f0f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.725239 [ 23597 ] {02ae1867-d781-4b88-b3ee-c9f8f697098b} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000030f36f0f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.865504 [ 22858 ] {cc91f79e-3b4d-4c81-bb15-48deced2b71c} executeQuery: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:48992) (comment: 01493_alter_remove_wrong_default.sql) (in query: ALTER TABLE default_table MODIFY COLUMN key REMOVE MATERIALIZED;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208ba53 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.865692 [ 22858 ] {cc91f79e-3b4d-4c81-bb15-48deced2b71c} TCPHandler: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208ba53 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.889531 [ 3522 ] {ae39cd17-ae25-4798-9c91-1ccef2dc55d3} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:49012) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.904276 [ 3522 ] {ae39cd17-ae25-4798-9c91-1ccef2dc55d3} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.911521 [ 22858 ] {694ea09b-f3ee-45aa-a0a7-bf7b8639966a} executeQuery: Code: 36. DB::Exception: Cannot remove ALIAS from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:48992) (comment: 01493_alter_remove_wrong_default.sql) (in query: ALTER TABLE default_table MODIFY COLUMN key REMOVE ALIAS;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b967 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.911761 [ 22858 ] {694ea09b-f3ee-45aa-a0a7-bf7b8639966a} TCPHandler: Code: 36. DB::Exception: Cannot remove ALIAS from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b967 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.948491 [ 22858 ] {156b3cc5-0e6d-4e1c-8645-dbdaf47ce204} executeQuery: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:48992) (comment: 01493_alter_remove_wrong_default.sql) (in query: ALTER TABLE default_table MODIFY COLUMN value1 REMOVE DEFAULT;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b6e7 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.948741 [ 22858 ] {156b3cc5-0e6d-4e1c-8645-dbdaf47ce204} TCPHandler: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b6e7 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.950900 [ 22858 ] {cf3ee087-4c31-4dca-b592-f2890ef2ea37} executeQuery: Code: 36. DB::Exception: Cannot remove ALIAS from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:48992) (comment: 01493_alter_remove_wrong_default.sql) (in query: ALTER TABLE default_table MODIFY COLUMN value1 REMOVE ALIAS;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b967 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.951066 [ 22858 ] {cf3ee087-4c31-4dca-b592-f2890ef2ea37} TCPHandler: Code: 36. DB::Exception: Cannot remove ALIAS from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b967 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.952741 [ 22858 ] {1bcb6afe-60fe-4910-a28a-5ca63511c3da} executeQuery: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:48992) (comment: 01493_alter_remove_wrong_default.sql) (in query: ALTER TABLE default_table MODIFY COLUMN value2 REMOVE DEFAULT;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b6e7 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.952882 [ 22858 ] {1bcb6afe-60fe-4910-a28a-5ca63511c3da} TCPHandler: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b6e7 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.959183 [ 22858 ] {8092e537-a78d-4890-b058-bcac75a38938} executeQuery: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:48992) (comment: 01493_alter_remove_wrong_default.sql) (in query: ALTER TABLE default_table MODIFY COLUMN value2 REMOVE MATERIALIZED;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208ba53 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:45.959302 [ 22858 ] {8092e537-a78d-4890-b058-bcac75a38938} TCPHandler: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208ba53 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.004906 [ 23597 ] {3aaab7aa-36b4-4508-9114-09705d369b2f} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have DEFAULT, cannot remove it. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49072) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (in query: -- just nothing happened ALTER TABLE no_prop_table MODIFY COLUMN some_column REMOVE DEFAULT;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b5fb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.004916 [ 23628 ] {2eab82f8-505c-4aba-9772-23f9a80866be} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:49076) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.004958 [ 48606 ] {225ca7e3-66e7-4b50-926f-93b422c19cfa} executeQuery: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. Maybe you meant test_pmiaicjp.t2?. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:49090) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.005167 [ 23628 ] {2eab82f8-505c-4aba-9772-23f9a80866be} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.005398 [ 48606 ] {225ca7e3-66e7-4b50-926f-93b422c19cfa} TCPHandler: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. Maybe you meant test_pmiaicjp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.005784 [ 23597 ] {3aaab7aa-36b4-4508-9114-09705d369b2f} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have DEFAULT, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b5fb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.022778 [ 23597 ] {eb832017-c360-4606-ab38-f3eead71524f} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have MATERIALIZED, cannot remove it. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49072) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (in query: ALTER TABLE no_prop_table MODIFY COLUMN some_column REMOVE MATERIALIZED;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b52e 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.023001 [ 23597 ] {eb832017-c360-4606-ab38-f3eead71524f} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have MATERIALIZED, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b52e 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.042615 [ 48606 ] {1358e581-d073-4367-86f4-bf4908120f6e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:49102) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000030f36f0f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.042863 [ 48606 ] {1358e581-d073-4367-86f4-bf4908120f6e} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000030f36f0f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.043030 [ 23597 ] {2bad318d-600d-44c6-a11c-9e3932f1727b} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have ALIAS, cannot remove it. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49072) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (in query: ALTER TABLE no_prop_table MODIFY COLUMN some_column REMOVE ALIAS;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b468 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.043161 [ 23597 ] {2bad318d-600d-44c6-a11c-9e3932f1727b} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have ALIAS, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b468 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.062345 [ 23597 ] {1d376de9-e0e5-42d6-8e98-e1bd47542355} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have TTL, cannot remove it. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49072) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (in query: ALTER TABLE no_prop_table MODIFY COLUMN some_column REMOVE CODEC;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208bb1b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.062665 [ 23597 ] {1d376de9-e0e5-42d6-8e98-e1bd47542355} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have TTL, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208bb1b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.085210 [ 23597 ] {4c5271af-7795-46d0-9061-6fe2bbed0156} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have COMMENT, cannot remove it. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49072) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (in query: ALTER TABLE no_prop_table MODIFY COLUMN some_column REMOVE COMMENT;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b87b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.085438 [ 23597 ] {4c5271af-7795-46d0-9061-6fe2bbed0156} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have COMMENT, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b87b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.101870 [ 23597 ] {8a9e5883-aa71-479f-a1df-83f1bd915187} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have TTL, cannot remove it. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49072) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (in query: ALTER TABLE no_prop_table MODIFY COLUMN some_column REMOVE TTL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b7ad 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.102063 [ 23597 ] {8a9e5883-aa71-479f-a1df-83f1bd915187} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have TTL, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b7ad 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.125795 [ 23597 ] {325893a7-96ba-4e1a-b37f-ee1454221374} executeQuery: Code: 36. DB::Exception: Table doesn't have any table TTL expression, cannot remove. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49072) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (in query: ALTER TABLE no_prop_table REMOVE TTL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a031 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.125975 [ 23597 ] {325893a7-96ba-4e1a-b37f-ee1454221374} TCPHandler: Code: 36. DB::Exception: Table doesn't have any table TTL expression, cannot remove. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a031 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.200912 [ 34946 ] {4bfafd49-754c-42c8-9270-eac69a70c52f} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:49182) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.201030 [ 34946 ] {4bfafd49-754c-42c8-9270-eac69a70c52f} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.250157 [ 48598 ] {7b1ed3c4-70c5-41c2-89eb-88185ecb9e32} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:49218) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.250276 [ 48598 ] {7b1ed3c4-70c5-41c2-89eb-88185ecb9e32} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.474813 [ 34946 ] {f4294d60-856e-48af-a9cb-74bbd9e238d6} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:49308) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.474945 [ 34946 ] {f4294d60-856e-48af-a9cb-74bbd9e238d6} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.475441 [ 48598 ] {38bb1739-6afb-4d3f-a56c-823a2a1d87f2} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:49314) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.475917 [ 48598 ] {38bb1739-6afb-4d3f-a56c-823a2a1d87f2} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.699710 [ 34946 ] {569379aa-7d47-415a-9975-148cc9e523e9} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:49412) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.699826 [ 34946 ] {569379aa-7d47-415a-9975-148cc9e523e9} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.701023 [ 48598 ] {1bdc99e0-30d9-45b4-ac94-f3ed82cb2cfb} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:49426) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.701179 [ 48598 ] {1bdc99e0-30d9-45b4-ac94-f3ed82cb2cfb} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.903956 [ 23553 ] {8a27266c-5363-4099-8880-414f3be4c244} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:49510) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.904060 [ 23553 ] {8a27266c-5363-4099-8880-414f3be4c244} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.928907 [ 23553 ] {bd641a08-779b-468e-8a13-9eddc894c870} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:49544) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:46.929051 [ 23553 ] {bd641a08-779b-468e-8a13-9eddc894c870} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:47.136771 [ 48631 ] {c68bb0c9-943d-4893-8597-b103f3c59c8a} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:49612) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:47.136933 [ 48631 ] {c68bb0c9-943d-4893-8597-b103f3c59c8a} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:47.164777 [ 48631 ] {d1e09815-7145-41ca-b562-d1e0053f669f} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:49646) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:47.164892 [ 48631 ] {d1e09815-7145-41ca-b562-d1e0053f669f} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:47.419053 [ 23498 ] {6c8e0bc6-8653-4478-82fa-defc16b02560} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:49722) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:47.419165 [ 23498 ] {6c8e0bc6-8653-4478-82fa-defc16b02560} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:47.426121 [ 48631 ] {825c0a20-8ba9-41df-a28f-47b0a73ad006} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:49734) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:47.426227 [ 48631 ] {825c0a20-8ba9-41df-a28f-47b0a73ad006} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:47.636825 [ 48631 ] {448030be-68ca-43c8-8629-2add1903a27b} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:49844) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:47.636954 [ 48631 ] {448030be-68ca-43c8-8629-2add1903a27b} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:47.639526 [ 22863 ] {3c41a1d9-ec4b-49e3-adbe-7e4e56ff5def} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:49858) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:47.639634 [ 22863 ] {3c41a1d9-ec4b-49e3-adbe-7e4e56ff5def} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:47.845541 [ 23553 ] {81166e87-eddc-4de6-92e5-3571d3c799d6} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:49926) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:47.845699 [ 23553 ] {81166e87-eddc-4de6-92e5-3571d3c799d6} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:47.867438 [ 48631 ] {243a2b72-6307-4c3e-b2c9-ce4b96c33c20} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:49940) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:47.867604 [ 48631 ] {243a2b72-6307-4c3e-b2c9-ce4b96c33c20} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:48.064466 [ 22866 ] {835065b4-3548-4aed-a289-5b3cf9d3f650} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:50014) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:48.064621 [ 22866 ] {835065b4-3548-4aed-a289-5b3cf9d3f650} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:48.095444 [ 48631 ] {f6033795-d752-44e6-bc8e-a828196a5aef} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:50020) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:48.095591 [ 48631 ] {f6033795-d752-44e6-bc8e-a828196a5aef} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:48.308714 [ 22859 ] {786b17c5-5d9d-4d58-af72-d58718c534e2} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:50112) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:48.308842 [ 22859 ] {786b17c5-5d9d-4d58-af72-d58718c534e2} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:48.336982 [ 48631 ] {6a9ae553-6108-4b37-8ec4-efcf51c88711} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:50116) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:48.337116 [ 48631 ] {6a9ae553-6108-4b37-8ec4-efcf51c88711} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:48.523878 [ 48631 ] {91e1724e-7124-47ed-98cb-2071f4ebf7c0} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:50172) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:48.524029 [ 48631 ] {91e1724e-7124-47ed-98cb-2071f4ebf7c0} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:48.586296 [ 22866 ] {23ea7fec-c17a-4ed0-a63a-dede5bec24b0} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:50220) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:48.586424 [ 22866 ] {23ea7fec-c17a-4ed0-a63a-dede5bec24b0} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:48.728903 [ 48631 ] {0a936bca-2ad6-4fa9-bbc7-5347104cdd5f} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:50280) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:48.729054 [ 48631 ] {0a936bca-2ad6-4fa9-bbc7-5347104cdd5f} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:48.832359 [ 48631 ] {0b5c732b-ed58-4807-b92d-13f12f8eac8f} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:50302) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:48.832533 [ 48631 ] {0b5c732b-ed58-4807-b92d-13f12f8eac8f} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:48.946448 [ 22866 ] {00255099-a16c-4a99-8348-debcd942b478} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:39372) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:48.946615 [ 22866 ] {00255099-a16c-4a99-8348-debcd942b478} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:49.082867 [ 22866 ] {9473bec3-12b7-4c79-a3a8-56e207e641ba} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:39406) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:49.083057 [ 22866 ] {9473bec3-12b7-4c79-a3a8-56e207e641ba} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:49.162448 [ 48631 ] {2d09b78e-e57b-425a-b0fa-7b79d1a09130} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:39462) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:49.162591 [ 48631 ] {2d09b78e-e57b-425a-b0fa-7b79d1a09130} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:49.301829 [ 23610 ] {3d8c6c7d-e464-439a-9b5e-638921b5f7c6} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:39542) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:49.302043 [ 23610 ] {3d8c6c7d-e464-439a-9b5e-638921b5f7c6} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:49.453310 [ 48599 ] {29260088-97ad-4eb5-bf9f-e810b134d0b5} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:39606) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:49.453465 [ 48599 ] {29260088-97ad-4eb5-bf9f-e810b134d0b5} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:49.599051 [ 48599 ] {c1e95fe5-1157-41fe-aa5d-8596cd85e1b6} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:39650) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:49.599184 [ 48599 ] {c1e95fe5-1157-41fe-aa5d-8596cd85e1b6} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:49.656472 [ 23606 ] {d4276551-7fdf-487b-97b6-60bd2f2a78e2} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:39676) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:49.656712 [ 23606 ] {d4276551-7fdf-487b-97b6-60bd2f2a78e2} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:49.890195 [ 23620 ] {adf8f23a-11d6-4cfc-b8bc-38cde45b0515} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:39752) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:49.890300 [ 23620 ] {adf8f23a-11d6-4cfc-b8bc-38cde45b0515} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:49.969950 [ 48599 ] {5d7552da-7fcd-4498-b362-ab98dd8c1341} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:39786) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:49.970060 [ 48599 ] {5d7552da-7fcd-4498-b362-ab98dd8c1341} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:50.098632 [ 23620 ] {2cf40352-27a7-4903-88fe-df5cccdf8fb1} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:39820) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:50.098826 [ 23620 ] {2cf40352-27a7-4903-88fe-df5cccdf8fb1} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:50.254202 [ 23611 ] {2e896c43-2b90-4773-ac2c-135a136e515f} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:39888) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:50.254318 [ 23611 ] {2e896c43-2b90-4773-ac2c-135a136e515f} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:50.315158 [ 23621 ] {7fbda621-c97a-4428-9b65-745f609a8a64} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:39894) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:50.315277 [ 23621 ] {7fbda621-c97a-4428-9b65-745f609a8a64} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:50.456997 [ 23621 ] {6853d67d-8395-43aa-bb06-498cf2a6efec} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:39936) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:50.457130 [ 23621 ] {6853d67d-8395-43aa-bb06-498cf2a6efec} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:50.520395 [ 23587 ] {5f682f4f-a676-44f2-a64c-cc19b6f31fd9} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:39948) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:50.520562 [ 23587 ] {5f682f4f-a676-44f2-a64c-cc19b6f31fd9} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:50.647504 [ 23611 ] {df1c20c2-e49d-4da6-8794-7750850718f9} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40022) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:50.647641 [ 23611 ] {df1c20c2-e49d-4da6-8794-7750850718f9} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:50.741087 [ 23611 ] {41f2c17f-d24a-4248-b222-f9628999c391} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40024) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:50.741294 [ 23611 ] {41f2c17f-d24a-4248-b222-f9628999c391} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:50.931010 [ 23606 ] {b3aee2e7-6c22-4b3f-bbd4-f9bbc3ad23fb} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40066) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:50.931137 [ 23606 ] {b3aee2e7-6c22-4b3f-bbd4-f9bbc3ad23fb} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:50.964870 [ 23611 ] {c31c2778-b566-40eb-a1b6-a5a716179727} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40080) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:50.965008 [ 23611 ] {c31c2778-b566-40eb-a1b6-a5a716179727} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.123005 [ 48602 ] {44933357-31b5-4daf-a8f6-a3ed4db04322} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40152) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.123113 [ 48602 ] {44933357-31b5-4daf-a8f6-a3ed4db04322} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.174788 [ 48603 ] {83584633-3fb5-4cfc-b2f2-a4d613e53aef} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40170) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.174923 [ 48603 ] {83584633-3fb5-4cfc-b2f2-a4d613e53aef} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.342971 [ 48603 ] {a8769260-0512-4957-96e6-94edab2ab480} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40218) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.343139 [ 48603 ] {a8769260-0512-4957-96e6-94edab2ab480} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.475122 [ 48603 ] {cf8d5975-6b34-4490-88c4-ee998f20859a} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40240) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.475247 [ 48603 ] {cf8d5975-6b34-4490-88c4-ee998f20859a} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.550039 [ 48603 ] {219f3196-47b0-4d98-b983-9f96be795a8a} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40280) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.550204 [ 48603 ] {219f3196-47b0-4d98-b983-9f96be795a8a} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.687570 [ 48602 ] {a810eed8-5050-4470-8bf9-45222d85ffe5} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40310) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.687723 [ 48602 ] {a810eed8-5050-4470-8bf9-45222d85ffe5} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.793525 [ 48602 ] {0d04b20c-1ce4-4877-bc0b-e314da8b1e03} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40326) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.793682 [ 48602 ] {0d04b20c-1ce4-4877-bc0b-e314da8b1e03} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.853548 [ 48602 ] {9b1e0d86-957a-4b6e-92fb-52065247b55f} executeQuery: Code: 60. DB::Exception: Table test_pmiaicjp.t2 does not exist. Maybe you meant test_pmiaicjp.t1?. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40354) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.853708 [ 48602 ] {9b1e0d86-957a-4b6e-92fb-52065247b55f} TCPHandler: Code: 60. DB::Exception: Table test_pmiaicjp.t2 does not exist. Maybe you meant test_pmiaicjp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.874355 [ 48602 ] {21911323-f492-4f63-9fab-64a196565bbf} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40364) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000030f36f0f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.874532 [ 48602 ] {21911323-f492-4f63-9fab-64a196565bbf} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000030f36f0f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.898119 [ 22860 ] {242bebe6-c3c7-4bba-b3df-13ffa02f1e4b} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40398) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:51.898262 [ 22860 ] {242bebe6-c3c7-4bba-b3df-13ffa02f1e4b} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.054035 [ 48602 ] {9db9f108-564a-4d16-b660-f9347bb7784d} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40416) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.054246 [ 48602 ] {9db9f108-564a-4d16-b660-f9347bb7784d} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.111342 [ 48602 ] {44dd28a3-2892-44a5-9670-2b013850b2a3} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40458) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.111471 [ 48602 ] {44dd28a3-2892-44a5-9670-2b013850b2a3} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.302530 [ 48602 ] {e2dfed4c-389d-46ac-b870-3acd94212255} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40494) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.302667 [ 48602 ] {e2dfed4c-389d-46ac-b870-3acd94212255} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.331309 [ 5753 ] {b2a6bbd2-ffb7-42f0-9139-29aa742f8d89} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40514) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.331443 [ 5753 ] {b2a6bbd2-ffb7-42f0-9139-29aa742f8d89} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.529843 [ 48602 ] {b5f8ef30-abd0-42a6-8eb6-51a9320922f6} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40576) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.529995 [ 48602 ] {b5f8ef30-abd0-42a6-8eb6-51a9320922f6} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.543722 [ 48602 ] {181a8f4c-fe1a-4878-8c97-46d310e4f115} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40584) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.543897 [ 48602 ] {181a8f4c-fe1a-4878-8c97-46d310e4f115} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.760020 [ 48602 ] {4c3ec9b5-078e-4d99-94ee-78724ecc62a0} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40636) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.760191 [ 48602 ] {4c3ec9b5-078e-4d99-94ee-78724ecc62a0} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.778148 [ 48602 ] {4ee7a6d6-0ee2-4f7c-b36f-87e5dd91c05b} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40642) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.778308 [ 48602 ] {4ee7a6d6-0ee2-4f7c-b36f-87e5dd91c05b} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.898648 [ 48602 ] {c6c90fca-d1a3-467a-a320-f55251565da3} executeQuery: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. Maybe you meant test_pmiaicjp.t2?. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40696) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.898832 [ 48602 ] {c6c90fca-d1a3-467a-a320-f55251565da3} TCPHandler: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. Maybe you meant test_pmiaicjp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.905098 [ 22860 ] {daaca1fe-3a91-4952-8612-7b82172027fe} executeQuery: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. Maybe you meant test_pmiaicjp.t2?. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40710) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.905322 [ 22860 ] {daaca1fe-3a91-4952-8612-7b82172027fe} TCPHandler: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. Maybe you meant test_pmiaicjp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.906454 [ 48626 ] {518f1ef8-21ca-4a9c-bf39-38c497db77f7} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40726) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:52.906682 [ 48626 ] {518f1ef8-21ca-4a9c-bf39-38c497db77f7} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:53.009476 [ 48602 ] {55a28d09-6971-4cc3-8a65-6c88995b146c} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40740) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:53.009608 [ 48602 ] {55a28d09-6971-4cc3-8a65-6c88995b146c} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:53.240839 [ 48602 ] {6559d4d8-53a9-444a-a4bc-2d59ac683bd4} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40832) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:53.240959 [ 48602 ] {6559d4d8-53a9-444a-a4bc-2d59ac683bd4} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:53.242094 [ 22860 ] {616011cf-7216-49e4-b307-2e1abd6fe5c5} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40848) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:53.242221 [ 22860 ] {616011cf-7216-49e4-b307-2e1abd6fe5c5} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:53.483493 [ 48602 ] {f45cc9ea-a87e-4b47-8d73-2f0590b1f1d8} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40924) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:53.483629 [ 48602 ] {f45cc9ea-a87e-4b47-8d73-2f0590b1f1d8} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:53.502959 [ 22860 ] {568bcbef-e5f7-4c17-8839-83eb965a5a23} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40946) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:53.503143 [ 22860 ] {568bcbef-e5f7-4c17-8839-83eb965a5a23} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:53.711311 [ 10241 ] {13fdd912-aa52-434f-99aa-99725e40d90a} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41024) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:53.711440 [ 10241 ] {13fdd912-aa52-434f-99aa-99725e40d90a} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:53.745313 [ 23586 ] {8856b7dd-50e3-4efb-bc59-7955f3299813} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41030) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:53.745436 [ 23586 ] {8856b7dd-50e3-4efb-bc59-7955f3299813} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:53.909631 [ 48624 ] {ffc39e10-1e01-4b08-88a6-6b9862a86673} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41090) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:53.909768 [ 48624 ] {ffc39e10-1e01-4b08-88a6-6b9862a86673} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:53.976455 [ 12525 ] {0331e330-5315-4de8-95ea-d12237a78602} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41134) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:53.976675 [ 12525 ] {0331e330-5315-4de8-95ea-d12237a78602} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:54.126670 [ 23586 ] {e031dc0e-0b2d-4c03-ac45-99654af1ea3a} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41168) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:54.126806 [ 23586 ] {e031dc0e-0b2d-4c03-ac45-99654af1ea3a} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:54.213037 [ 23586 ] {b5c122eb-40a2-4b80-93dc-0c8f35810559} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41178) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:54.213166 [ 23586 ] {b5c122eb-40a2-4b80-93dc-0c8f35810559} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:54.380813 [ 10241 ] {526a9b5c-357f-46bc-9fd6-5abe796fc534} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41250) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:54.380966 [ 10241 ] {526a9b5c-357f-46bc-9fd6-5abe796fc534} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:54.425878 [ 48581 ] {ce01e9dd-8a7f-4ebe-8d87-f3ba34b61816} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41272) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:54.426007 [ 48581 ] {ce01e9dd-8a7f-4ebe-8d87-f3ba34b61816} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:54.619559 [ 10241 ] {570f28aa-3a44-4f84-885f-6395e532bf8e} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41350) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:54.619683 [ 10241 ] {570f28aa-3a44-4f84-885f-6395e532bf8e} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:54.650477 [ 10241 ] {dc45bda5-29ab-41b0-8d19-d3c3964be51b} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41358) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:54.650629 [ 10241 ] {dc45bda5-29ab-41b0-8d19-d3c3964be51b} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:54.864251 [ 23590 ] {f945b8a7-d3cf-41a3-8015-391b42107e00} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41458) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:54.864437 [ 23590 ] {f945b8a7-d3cf-41a3-8015-391b42107e00} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:54.931350 [ 48581 ] {39dd2fd3-9e65-4888-aa18-077ef31c8d43} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41496) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:54.931464 [ 48581 ] {39dd2fd3-9e65-4888-aa18-077ef31c8d43} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:54.994437 [ 23590 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::1]:41514). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:14:55.201996 [ 48606 ] {66c9b34e-98d5-46d8-9efe-530ef3a58ff8} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41562) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:55.202131 [ 48606 ] {66c9b34e-98d5-46d8-9efe-530ef3a58ff8} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:55.203161 [ 34946 ] {da97c734-907f-4631-814b-976fa7dd7998} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41564) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:55.203289 [ 34946 ] {da97c734-907f-4631-814b-976fa7dd7998} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:55.226063 [ 34946 ] {d8d8c5c2-f731-449c-ac67-c774c7681c7a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41606) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:55.226214 [ 34946 ] {d8d8c5c2-f731-449c-ac67-c774c7681c7a} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:55.233374 [ 14974 ] {96a2bfcf-0096-45d3-aa67-0135e77d1750} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41628) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:55.233501 [ 14974 ] {96a2bfcf-0096-45d3-aa67-0135e77d1750} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:55.620879 [ 23590 ] {212a2fe5-9e23-4ac9-9b15-2d35afb0d1cd} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41742) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:55.621014 [ 23590 ] {212a2fe5-9e23-4ac9-9b15-2d35afb0d1cd} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:55.628698 [ 14974 ] {ae0ca498-d0a7-4fd7-9868-287f2dbe651a} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41754) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:55.628835 [ 14974 ] {ae0ca498-d0a7-4fd7-9868-287f2dbe651a} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:55.850495 [ 23590 ] {eb9ba41c-75b6-441a-8dd0-0eff91e6dc8f} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41866) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:55.850645 [ 23590 ] {eb9ba41c-75b6-441a-8dd0-0eff91e6dc8f} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:55.866881 [ 23590 ] {09ab1f2f-a665-46eb-a6c5-284bff573ee3} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41878) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:55.867039 [ 23590 ] {09ab1f2f-a665-46eb-a6c5-284bff573ee3} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:56.065686 [ 23590 ] {c199b6d7-88b8-465a-b923-6bd193e9cd7b} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41968) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:56.065808 [ 23590 ] {c199b6d7-88b8-465a-b923-6bd193e9cd7b} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:56.105130 [ 23590 ] {ef02bc2f-5e99-41ea-9d84-3a794528b001} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41984) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:56.105275 [ 23590 ] {ef02bc2f-5e99-41ea-9d84-3a794528b001} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:56.284135 [ 14974 ] {32326089-5b0a-4cad-8733-0efd852e4275} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42060) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:56.284288 [ 14974 ] {32326089-5b0a-4cad-8733-0efd852e4275} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:56.327786 [ 23590 ] {d97b227a-67ce-4afe-8ade-1ada5e8e5159} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42074) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:56.327899 [ 23590 ] {d97b227a-67ce-4afe-8ade-1ada5e8e5159} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:56.530188 [ 23622 ] {2314a7a9-8907-433e-8c8a-8f8effa1c7a5} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42134) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:56.530312 [ 23622 ] {2314a7a9-8907-433e-8c8a-8f8effa1c7a5} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:56.541323 [ 23622 ] {47f47ef9-26c7-479f-88c5-52cd9cb92bc4} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42164) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:56.541480 [ 23622 ] {47f47ef9-26c7-479f-88c5-52cd9cb92bc4} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:56.756015 [ 14974 ] {b43028ac-4221-4dc0-af1c-c364f444749d} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42230) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:56.756186 [ 14974 ] {b43028ac-4221-4dc0-af1c-c364f444749d} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:56.776576 [ 14974 ] {a008953d-9c31-4d84-83b4-ca81d58270d7} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42266) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:56.776769 [ 14974 ] {a008953d-9c31-4d84-83b4-ca81d58270d7} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:56.972196 [ 23628 ] {9bc3ffcf-23b9-44de-b91a-1c41fe632ac0} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42350) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:56.972299 [ 23628 ] {9bc3ffcf-23b9-44de-b91a-1c41fe632ac0} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.020510 [ 22863 ] {a70b5817-226e-47f1-a2c8-ea60d3ce5ed6} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42386) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.020698 [ 22863 ] {a70b5817-226e-47f1-a2c8-ea60d3ce5ed6} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.181608 [ 23628 ] {716650b4-bedb-44d6-ad91-07f660f530e1} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42446) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.181782 [ 23628 ] {716650b4-bedb-44d6-ad91-07f660f530e1} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.297187 [ 22863 ] {8b0cb7cf-f317-45f0-9a41-36a9dfa2ed65} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42496) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.297404 [ 22863 ] {8b0cb7cf-f317-45f0-9a41-36a9dfa2ed65} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.300499 [ 23597 ] {2cbe44dc-bf7e-40d3-b4c5-c4cac63e7577} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have DEFAULT, cannot remove it. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49072) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (in query: ALTER TABLE r_no_prop_table MODIFY COLUMN some_column REMOVE DEFAULT;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b5fb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.300633 [ 23597 ] {2cbe44dc-bf7e-40d3-b4c5-c4cac63e7577} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have DEFAULT, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b5fb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.302040 [ 23597 ] {37780088-9537-4ea8-8b58-19d1d75b1f81} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have MATERIALIZED, cannot remove it. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49072) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (in query: ALTER TABLE r_no_prop_table MODIFY COLUMN some_column REMOVE MATERIALIZED;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b52e 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.302137 [ 23597 ] {37780088-9537-4ea8-8b58-19d1d75b1f81} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have MATERIALIZED, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b52e 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.303197 [ 23597 ] {96355b2f-9e89-44f1-bf28-f77008fcac5d} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have ALIAS, cannot remove it. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49072) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (in query: ALTER TABLE r_no_prop_table MODIFY COLUMN some_column REMOVE ALIAS;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b468 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.303284 [ 23597 ] {96355b2f-9e89-44f1-bf28-f77008fcac5d} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have ALIAS, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b468 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.305118 [ 23597 ] {dd3afdba-ecb8-4ed5-ad6d-1d5405078875} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have TTL, cannot remove it. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49072) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (in query: ALTER TABLE r_no_prop_table MODIFY COLUMN some_column REMOVE CODEC;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208bb1b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.305252 [ 23597 ] {dd3afdba-ecb8-4ed5-ad6d-1d5405078875} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have TTL, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208bb1b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.306555 [ 23597 ] {86f3ff5d-e708-4be6-a69d-a691af58d4ae} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have COMMENT, cannot remove it. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49072) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (in query: ALTER TABLE r_no_prop_table MODIFY COLUMN some_column REMOVE COMMENT;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b87b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.306652 [ 23597 ] {86f3ff5d-e708-4be6-a69d-a691af58d4ae} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have COMMENT, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b87b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.308156 [ 23597 ] {ea83e337-c7c2-4e2a-87dd-e57033bb2bfa} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have TTL, cannot remove it. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49072) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (in query: ALTER TABLE r_no_prop_table MODIFY COLUMN some_column REMOVE TTL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b7ad 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.308271 [ 23597 ] {ea83e337-c7c2-4e2a-87dd-e57033bb2bfa} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have TTL, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b7ad 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.310231 [ 23597 ] {7a6c592a-c554-46d6-a19c-20f80d95e3f9} executeQuery: Code: 36. DB::Exception: Table doesn't have any table TTL expression, cannot remove. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49072) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (in query: ALTER TABLE r_no_prop_table REMOVE TTL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a031 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.310382 [ 23597 ] {7a6c592a-c554-46d6-a19c-20f80d95e3f9} TCPHandler: Code: 36. DB::Exception: Table doesn't have any table TTL expression, cannot remove. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a031 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.314906 [ 23597 ] {015103cf-e01e-498f-bfc3-67511452f84c} executeQuery: Code: 36. DB::Exception: Column `some_column` doesn't have TTL, cannot remove it. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49072) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (in query: ALTER TABLE r_no_prop_table MODIFY COLUMN some_column REMOVE ttl;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b7ad 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.315099 [ 23597 ] {015103cf-e01e-498f-bfc3-67511452f84c} TCPHandler: Code: 36. DB::Exception: Column `some_column` doesn't have TTL, cannot remove it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208b7ad 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.317131 [ 23597 ] {8380cd9f-9b64-4d05-93d7-59814f321583} executeQuery: Code: 36. DB::Exception: Table doesn't have any table TTL expression, cannot remove. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:49072) (comment: 01493_alter_remove_no_property_zookeeper_long.sql) (in query: ALTER TABLE r_no_prop_table remove TTL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a031 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.317391 [ 23597 ] {8380cd9f-9b64-4d05-93d7-59814f321583} TCPHandler: Code: 36. DB::Exception: Table doesn't have any table TTL expression, cannot remove. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a031 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.393806 [ 23628 ] {0bda93f2-4e8d-45f6-afc5-1f901f6b7b4c} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42548) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.393991 [ 23628 ] {0bda93f2-4e8d-45f6-afc5-1f901f6b7b4c} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.524974 [ 22863 ] {73d2550f-7db0-45f2-b2dc-5ec60b3bcd52} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42592) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.525086 [ 22863 ] {73d2550f-7db0-45f2-b2dc-5ec60b3bcd52} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.612121 [ 23628 ] {bb4b8356-85e1-47bf-bbe0-d1ae974c1cd6} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42622) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.612242 [ 23628 ] {bb4b8356-85e1-47bf-bbe0-d1ae974c1cd6} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.735109 [ 23639 ] {6afdd50d-af81-4efc-9212-47bdf0c81df4} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42644) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.735214 [ 23639 ] {6afdd50d-af81-4efc-9212-47bdf0c81df4} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.843227 [ 34946 ] {2da69a37-497c-4037-ab0e-070834254a9b} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42668) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:57.843419 [ 34946 ] {2da69a37-497c-4037-ab0e-070834254a9b} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.020887 [ 34946 ] {cb11b18c-5856-49f6-a15f-f91765c9676b} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42714) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.021033 [ 34946 ] {cb11b18c-5856-49f6-a15f-f91765c9676b} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.120041 [ 22863 ] {454d709b-749e-4ec0-ad3f-ed786714991e} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42768) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.120174 [ 22863 ] {454d709b-749e-4ec0-ad3f-ed786714991e} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.297146 [ 34946 ] {73fbc98c-2585-4cae-b686-c42e588bd92c} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42816) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.297309 [ 34946 ] {73fbc98c-2585-4cae-b686-c42e588bd92c} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.338179 [ 23639 ] {1408c067-90ed-46b0-ba3c-aaa164fc13a2} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42848) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.338306 [ 23639 ] {1408c067-90ed-46b0-ba3c-aaa164fc13a2} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.518655 [ 34946 ] {1cd42953-97b1-4ebc-adc9-71314f1e882f} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42900) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.518794 [ 34946 ] {1cd42953-97b1-4ebc-adc9-71314f1e882f} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.551674 [ 22859 ] {55d0f494-e131-43ec-89bd-08e4022d92a9} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42924) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.551792 [ 22859 ] {55d0f494-e131-43ec-89bd-08e4022d92a9} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.745911 [ 22859 ] {bf094e94-6304-4965-b6f9-6ab1b3209e92} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42994) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.746045 [ 22859 ] {bf094e94-6304-4965-b6f9-6ab1b3209e92} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.757465 [ 22859 ] {be7baf43-fd8a-4668-8e0a-6e7d45979e55} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:43010) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.757603 [ 22859 ] {be7baf43-fd8a-4668-8e0a-6e7d45979e55} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.962594 [ 22859 ] {1c3e0a59-a10b-461f-8967-40c770d14a9d} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:52664) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.962728 [ 22859 ] {1c3e0a59-a10b-461f-8967-40c770d14a9d} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.967740 [ 48631 ] {5fc9ecc5-6a4b-4f42-8c34-9f9bd5116fb9} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:52674) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:58.967877 [ 48631 ] {5fc9ecc5-6a4b-4f42-8c34-9f9bd5116fb9} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:59.184744 [ 22859 ] {13c57f2b-2188-40b6-b7e5-3c905c98ff22} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:52724) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:59.184902 [ 22859 ] {13c57f2b-2188-40b6-b7e5-3c905c98ff22} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:59.201965 [ 48611 ] {b8b40d0a-12d0-4c31-87de-ba521f29fdb1} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:52744) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:59.202081 [ 48611 ] {b8b40d0a-12d0-4c31-87de-ba521f29fdb1} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:59.383754 [ 23610 ] {5b9217ef-bb74-4ea9-92d4-e1fc60a23d46} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:52786) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:59.383866 [ 23610 ] {5b9217ef-bb74-4ea9-92d4-e1fc60a23d46} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:59.428679 [ 23610 ] {765b81d1-d04b-4baa-bf0f-2980388e2467} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:52816) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:59.428821 [ 23610 ] {765b81d1-d04b-4baa-bf0f-2980388e2467} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:59.596786 [ 48611 ] {69b3a871-3b0e-47eb-a175-8bac9a6cbc18} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:52864) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:59.596901 [ 48611 ] {69b3a871-3b0e-47eb-a175-8bac9a6cbc18} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:59.688174 [ 48611 ] {6db4edb8-0dfb-453e-a5f8-b9bf1acfe499} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:52892) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:59.688331 [ 48611 ] {6db4edb8-0dfb-453e-a5f8-b9bf1acfe499} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:59.826572 [ 23621 ] {6a42892c-7676-4b8e-8a10-cd22690cfa0f} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:52944) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:59.826734 [ 23621 ] {6a42892c-7676-4b8e-8a10-cd22690cfa0f} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:59.908491 [ 48599 ] {8c66d493-7e96-4004-b842-7cde49d729a0} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:52974) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:14:59.908674 [ 48599 ] {8c66d493-7e96-4004-b842-7cde49d729a0} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:00.082424 [ 48611 ] {b67e965b-50cd-428b-9c17-247e9c6cdacf} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:52998) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:00.082702 [ 48611 ] {b67e965b-50cd-428b-9c17-247e9c6cdacf} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:00.146996 [ 48611 ] {05ae89b9-9544-40cd-8fce-94d437f1b2ac} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53026) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:00.147138 [ 48611 ] {05ae89b9-9544-40cd-8fce-94d437f1b2ac} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:00.316850 [ 23621 ] {08bfb2a3-b734-4d1b-9b15-2a9da3dfe269} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53090) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:00.317011 [ 23621 ] {08bfb2a3-b734-4d1b-9b15-2a9da3dfe269} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:00.361592 [ 23621 ] {3a19653f-5c41-439c-a51b-69e6be010308} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53116) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:00.361734 [ 23621 ] {3a19653f-5c41-439c-a51b-69e6be010308} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:00.555385 [ 48611 ] {2dea986a-5e67-4c12-8f9d-16dc41078b9f} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53164) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:00.555601 [ 48611 ] {2dea986a-5e67-4c12-8f9d-16dc41078b9f} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:00.576860 [ 23620 ] {ea13492d-e075-45bf-9338-7d7008cb9016} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53184) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:00.576973 [ 23620 ] {ea13492d-e075-45bf-9338-7d7008cb9016} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:00.809389 [ 14920 ] {e485c762-785e-47be-8f1d-fe0df32c5cee} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53246) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:00.809572 [ 14920 ] {e485c762-785e-47be-8f1d-fe0df32c5cee} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:00.813349 [ 730 ] {5a71dee7-70e4-4f36-a47b-ba514a5a95b4} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53256) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:00.813512 [ 730 ] {5a71dee7-70e4-4f36-a47b-ba514a5a95b4} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:01.049937 [ 23587 ] {fafaca8e-37ab-4e55-afcc-8efcef3bb942} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53300) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:01.050623 [ 23587 ] {fafaca8e-37ab-4e55-afcc-8efcef3bb942} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:01.050682 [ 730 ] {22094eca-3ac6-4799-b18a-9d7ff1c1a01b} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53306) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:01.051022 [ 730 ] {22094eca-3ac6-4799-b18a-9d7ff1c1a01b} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:01.258059 [ 730 ] {ac87b878-a2b2-4c2c-83a4-411bd1d5a4dd} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53354) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:01.258223 [ 730 ] {ac87b878-a2b2-4c2c-83a4-411bd1d5a4dd} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:01.291773 [ 730 ] {e8bf0d6d-3cf1-45bd-b644-04559ffaefbc} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53356) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:01.291905 [ 730 ] {e8bf0d6d-3cf1-45bd-b644-04559ffaefbc} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:01.471783 [ 730 ] {8c6f300d-5008-48c9-848c-b955807ab18d} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53380) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:01.472043 [ 730 ] {8c6f300d-5008-48c9-848c-b955807ab18d} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:01.543530 [ 3522 ] {e7b9dc81-8068-4664-ac00-16f908350ff0} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53452) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:01.543717 [ 3522 ] {e7b9dc81-8068-4664-ac00-16f908350ff0} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:01.709381 [ 23611 ] {a4993979-5efc-4bc8-bf96-df20cc0f1781} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53478) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:01.709639 [ 23611 ] {a4993979-5efc-4bc8-bf96-df20cc0f1781} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:01.781275 [ 23611 ] {6e3d9258-5fbc-4d62-b847-9d75b52f5aca} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53488) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:01.781509 [ 23611 ] {6e3d9258-5fbc-4d62-b847-9d75b52f5aca} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:01.917070 [ 3522 ] {e46b71d8-1077-46e0-addc-55e074ed382f} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53518) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:01.917218 [ 3522 ] {e46b71d8-1077-46e0-addc-55e074ed382f} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:02.001031 [ 3522 ] {4801ce30-6f8e-435b-9045-1fb285e40652} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53538) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:02.001178 [ 3522 ] {4801ce30-6f8e-435b-9045-1fb285e40652} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:02.146107 [ 23635 ] {44963616-7dd2-4028-9c0e-87fb41c0605f} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53592) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:02.146276 [ 23635 ] {44963616-7dd2-4028-9c0e-87fb41c0605f} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:02.221118 [ 23635 ] {3392548c-8e60-43a7-9cee-8ce5b59c4e5b} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53606) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:02.221264 [ 23635 ] {3392548c-8e60-43a7-9cee-8ce5b59c4e5b} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:02.344003 [ 23635 ] {aee559b1-e2d1-4d50-a91b-741f09467f13} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53648) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:02.344120 [ 23635 ] {aee559b1-e2d1-4d50-a91b-741f09467f13} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:02.484667 [ 23635 ] {c9ed4938-c1e7-4a1b-bab4-6821cd757614} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53668) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:02.484836 [ 23635 ] {c9ed4938-c1e7-4a1b-bab4-6821cd757614} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:02.578149 [ 23635 ] {e47d4e07-5001-4411-a234-afb6648a194b} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53702) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:02.581565 [ 23635 ] {e47d4e07-5001-4411-a234-afb6648a194b} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:02.722842 [ 48602 ] {9e9b6352-9bbe-497f-ba81-17aba6dbbc19} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53720) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:02.722949 [ 48602 ] {9e9b6352-9bbe-497f-ba81-17aba6dbbc19} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:02.807944 [ 22860 ] {5719fc15-039f-4c9d-925d-7e7bd7922d63} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53750) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:02.808094 [ 22860 ] {5719fc15-039f-4c9d-925d-7e7bd7922d63} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:02.998901 [ 22858 ] {c9b0abe9-1a2d-4e6f-b1ff-b259600ea634} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53786) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:02.999022 [ 22858 ] {c9b0abe9-1a2d-4e6f-b1ff-b259600ea634} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:03.024027 [ 22858 ] {785b7916-604f-42b8-9518-531f7417b07c} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53802) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:03.024176 [ 22858 ] {785b7916-604f-42b8-9518-531f7417b07c} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:03.239128 [ 48626 ] {c472b660-9f19-42a7-b9e9-31fc2a008678} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53874) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:03.239275 [ 48626 ] {c472b660-9f19-42a7-b9e9-31fc2a008678} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:03.312753 [ 12525 ] {adcb9264-cfa8-44cd-af63-5f91db1c5e61} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53902) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:03.314202 [ 12525 ] {adcb9264-cfa8-44cd-af63-5f91db1c5e61} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:03.426809 [ 48626 ] {8d32d848-d4f1-482f-a2dd-6a7d737c82cd} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53934) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:03.426932 [ 48626 ] {8d32d848-d4f1-482f-a2dd-6a7d737c82cd} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:03.537921 [ 48626 ] {8775d5da-984f-464b-bb51-1443bb9c6383} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53970) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:03.538042 [ 48626 ] {8775d5da-984f-464b-bb51-1443bb9c6383} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:03.635644 [ 23586 ] {b21db5db-910d-4f75-8cd1-b88c62e28795} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53990) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:03.635797 [ 23586 ] {b21db5db-910d-4f75-8cd1-b88c62e28795} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:03.740144 [ 48626 ] {b9354130-9af4-4d4c-bc1a-86fffd0dbef0} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54014) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:03.740291 [ 48626 ] {b9354130-9af4-4d4c-bc1a-86fffd0dbef0} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:03.847849 [ 48626 ] {c998554a-0172-4d12-ba94-752c1e45db40} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54054) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:03.847990 [ 48626 ] {c998554a-0172-4d12-ba94-752c1e45db40} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:03.989923 [ 23586 ] {eb12dea2-bddc-4639-a0f3-97deb42c0672} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54086) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:03.990125 [ 23586 ] {eb12dea2-bddc-4639-a0f3-97deb42c0672} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:04.092271 [ 23586 ] {dc79f54e-14a6-4c94-8dae-ff55876e0e46} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54098) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:04.092426 [ 23586 ] {dc79f54e-14a6-4c94-8dae-ff55876e0e46} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:04.257942 [ 23586 ] {a81528dd-8c18-465f-97be-c56d18c907bb} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54146) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:04.258120 [ 23586 ] {a81528dd-8c18-465f-97be-c56d18c907bb} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:04.305413 [ 23586 ] {16673459-c0a0-4c86-be67-549f61dadf1c} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54154) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:04.305603 [ 23586 ] {16673459-c0a0-4c86-be67-549f61dadf1c} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:04.496222 [ 23586 ] {9f739854-05df-4306-98d8-b45b53666d59} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54192) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:04.496349 [ 23586 ] {9f739854-05df-4306-98d8-b45b53666d59} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:04.510979 [ 23586 ] {2de2f39c-b7d1-4cb7-9a0b-68e15c2eabb4} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54204) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:04.511160 [ 23586 ] {2de2f39c-b7d1-4cb7-9a0b-68e15c2eabb4} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:04.720873 [ 48603 ] {78a3d939-8de4-4605-8d17-47884c4013ca} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54264) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:04.721027 [ 48603 ] {78a3d939-8de4-4605-8d17-47884c4013ca} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:04.748722 [ 10241 ] {48c00555-93a9-4605-8450-2c55edec8a13} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54284) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:04.748947 [ 10241 ] {48c00555-93a9-4605-8450-2c55edec8a13} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:04.957727 [ 48581 ] {2a395edf-a252-4f84-a717-81985bb3aa37} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54334) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:04.957879 [ 48581 ] {2a395edf-a252-4f84-a717-81985bb3aa37} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:04.976960 [ 48581 ] {714da1fe-d650-4042-ac7d-2f67958cc8bc} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54340) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:04.977069 [ 48581 ] {714da1fe-d650-4042-ac7d-2f67958cc8bc} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.259761 [ 23590 ] {07db637e-848c-4adf-926e-ad3e4c5acad2} executeQuery: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. Maybe you meant test_pmiaicjp.t2?. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:54404) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.259912 [ 23590 ] {07db637e-848c-4adf-926e-ad3e4c5acad2} TCPHandler: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. Maybe you meant test_pmiaicjp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.274808 [ 48602 ] {b4ac0bcf-3fad-4661-b82f-f26a239d1ad0} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::1]:53734). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:53734) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:2164: DB::TCPHandler::getQueryCancellationStatus() @ 0x00000000334ad5b4 7. ./build_docker/./src/Server/TCPHandler.cpp:0: bool std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000334c5145 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:99: DB::CompletedPipelineExecutor::execute() @ 0x000000003355697b 9. ./build_docker/./src/Server/TCPHandler.cpp:567: DB::TCPHandler::runImpl() @ 0x0000000033487a99 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.275085 [ 48602 ] {b4ac0bcf-3fad-4661-b82f-f26a239d1ad0} FileChecker: Will truncate file store/585/5857015c-48d9-4d65-a13c-637b14499434/data.bin that has size 158501945 to size 139461624 2025.03.05 21:15:05.284160 [ 48606 ] {06047765-7cca-458f-a980-eaf1d70be1c2} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:54460) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.284297 [ 48606 ] {06047765-7cca-458f-a980-eaf1d70be1c2} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.284420 [ 23590 ] {56b55e4d-8974-42b3-83dc-23daa61b1368} executeQuery: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. Maybe you meant test_iib6gz69.t2?. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:54436) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.285929 [ 23590 ] {56b55e4d-8974-42b3-83dc-23daa61b1368} TCPHandler: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. Maybe you meant test_iib6gz69.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.305302 [ 10241 ] {64067314-38f9-4eaa-97df-ab95dc5f7b48} executeQuery: Code: 218. DB::Exception: Table test_pmiaicjp.t2 is dropped or detached. (TABLE_IS_DROPPED) (version 24.3.12.76.altinitystable) (from [::1]:54316) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Storages/IStorage.cpp:64: DB::IStorage::lockForShare(String const&, std::chrono::duration> const&) @ 0x00000000320dd146 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033c9ef7a 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.305324 [ 22863 ] {36f68e81-fcdd-4e10-b903-5fa258c73dbc} executeQuery: Code: 60. DB::Exception: Table test_pmiaicjp.t2 does not exist. Maybe you meant test_pmiaicjp.t1?. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:54482) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.305351 [ 23586 ] {3e087210-dc11-4313-9c83-8d176dfe3e4f} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:54250). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:54250) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::TCPHandler::runImpl() @ 0x0000000033487bf2 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.305416 [ 23586 ] {3e087210-dc11-4313-9c83-8d176dfe3e4f} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:54250). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::TCPHandler::runImpl() @ 0x0000000033487bf2 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.307112 [ 10241 ] {64067314-38f9-4eaa-97df-ab95dc5f7b48} TCPHandler: Code: 218. DB::Exception: Table test_pmiaicjp.t2 is dropped or detached. (TABLE_IS_DROPPED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Storages/IStorage.cpp:64: DB::IStorage::lockForShare(String const&, std::chrono::duration> const&) @ 0x00000000320dd146 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033c9ef7a 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.307141 [ 22863 ] {36f68e81-fcdd-4e10-b903-5fa258c73dbc} TCPHandler: Code: 60. DB::Exception: Table test_pmiaicjp.t2 does not exist. Maybe you meant test_pmiaicjp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.307150 [ 23586 ] {3e087210-dc11-4313-9c83-8d176dfe3e4f} TCPHandler: Client has gone away. 2025.03.05 21:15:05.307930 [ 23639 ] {b8a92c08-14e4-4966-9a89-3773b80dac59} executeQuery: Code: 60. DB::Exception: Table test_pmiaicjp.t2 does not exist. Maybe you meant test_pmiaicjp.t1?. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:54490) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.308051 [ 23639 ] {b8a92c08-14e4-4966-9a89-3773b80dac59} TCPHandler: Code: 60. DB::Exception: Table test_pmiaicjp.t2 does not exist. Maybe you meant test_pmiaicjp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.315023 [ 48602 ] {b4ac0bcf-3fad-4661-b82f-f26a239d1ad0} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::1]:53734). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:2164: DB::TCPHandler::getQueryCancellationStatus() @ 0x00000000334ad5b4 7. ./build_docker/./src/Server/TCPHandler.cpp:0: bool std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x00000000334c5145 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:99: DB::CompletedPipelineExecutor::execute() @ 0x000000003355697b 9. ./build_docker/./src/Server/TCPHandler.cpp:567: DB::TCPHandler::runImpl() @ 0x0000000033487a99 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.315279 [ 48602 ] {b4ac0bcf-3fad-4661-b82f-f26a239d1ad0} TCPHandler: Client has gone away. 2025.03.05 21:15:05.460328 [ 22863 ] {093c4cee-5f58-4cf5-965a-0954f62834ef} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54522) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.460478 [ 22863 ] {093c4cee-5f58-4cf5-965a-0954f62834ef} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.466963 [ 23639 ] {c602676b-0ca5-43f9-84e8-293264251608} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54536) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.467086 [ 23639 ] {c602676b-0ca5-43f9-84e8-293264251608} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.687025 [ 23628 ] {3fb65495-26d6-4017-bcad-70507f9bceff} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54626) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.687174 [ 23628 ] {3fb65495-26d6-4017-bcad-70507f9bceff} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.697216 [ 22863 ] {06227bcf-2199-4d36-a08b-145ff8c6e18c} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54628) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.697354 [ 22863 ] {06227bcf-2199-4d36-a08b-145ff8c6e18c} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.914052 [ 23628 ] {841a0a63-94bd-4cc8-9372-aab5d951339f} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54692) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.914194 [ 23628 ] {841a0a63-94bd-4cc8-9372-aab5d951339f} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.927613 [ 23628 ] {225d4b36-76ba-4945-aa4d-0c24f9036486} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54714) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:05.927791 [ 23628 ] {225d4b36-76ba-4945-aa4d-0c24f9036486} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:06.213596 [ 23639 ] {4124bba6-1e10-4fe8-af34-72b414f3f9cc} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54816) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:06.213771 [ 23639 ] {4124bba6-1e10-4fe8-af34-72b414f3f9cc} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:06.242437 [ 23639 ] {2ee08e18-f6ae-407b-98ef-22e56b339741} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54830) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:06.242580 [ 23639 ] {2ee08e18-f6ae-407b-98ef-22e56b339741} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:06.455418 [ 22859 ] {c04043cf-3ded-4057-8a20-d6cc0d67a5ca} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54946) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:06.455543 [ 22859 ] {c04043cf-3ded-4057-8a20-d6cc0d67a5ca} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:06.465664 [ 48631 ] {82c0a8bd-c7d4-4dbf-8a83-6a207dd25c2e} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:54954) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:06.465841 [ 48631 ] {82c0a8bd-c7d4-4dbf-8a83-6a207dd25c2e} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:06.687685 [ 23639 ] {f6984416-d82a-4124-9d70-b7c239ee99b2} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:55026) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:06.687861 [ 23639 ] {f6984416-d82a-4124-9d70-b7c239ee99b2} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:06.693254 [ 22859 ] {99d5b740-2fbc-406a-8a39-4d5807e5ef54} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:55036) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:06.693424 [ 22859 ] {99d5b740-2fbc-406a-8a39-4d5807e5ef54} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:06.904033 [ 22866 ] {08f79d36-edf1-40e0-ace8-539c339c329a} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:55124) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:06.904241 [ 22866 ] {08f79d36-edf1-40e0-ace8-539c339c329a} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:06.976166 [ 34946 ] {fe42c644-973e-4a94-a6cf-bcfa84bd2242} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:55142) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:06.976296 [ 34946 ] {fe42c644-973e-4a94-a6cf-bcfa84bd2242} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:07.138443 [ 23639 ] {35a017de-11a3-4d0e-913c-85b26fa88b31} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:55212) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:07.138605 [ 23639 ] {35a017de-11a3-4d0e-913c-85b26fa88b31} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:07.228956 [ 22859 ] {bb087efd-2c4a-402c-b26d-457e1d8cbb73} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:55252) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:07.229068 [ 22859 ] {bb087efd-2c4a-402c-b26d-457e1d8cbb73} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:07.356236 [ 34946 ] {90056a3c-a7cd-4fa4-825c-af25a7ee1a9a} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:55286) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:07.356472 [ 34946 ] {90056a3c-a7cd-4fa4-825c-af25a7ee1a9a} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:07.510111 [ 23639 ] {ca33ed63-2c52-4af1-87cf-8cfc29f2035d} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:55306) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:07.510251 [ 23639 ] {ca33ed63-2c52-4af1-87cf-8cfc29f2035d} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:07.569636 [ 23639 ] {930d1ccd-9d8c-4087-9b58-f299e91e6660} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:55330) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:07.569758 [ 23639 ] {930d1ccd-9d8c-4087-9b58-f299e91e6660} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:07.762671 [ 34946 ] {d2126095-fc9d-4d7e-8abf-180882e37d69} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:55416) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:07.762785 [ 34946 ] {d2126095-fc9d-4d7e-8abf-180882e37d69} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:07.796183 [ 34946 ] {51729922-f904-4a02-95a8-784a9369dfb2} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:55436) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:07.796340 [ 34946 ] {51729922-f904-4a02-95a8-784a9369dfb2} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:07.982989 [ 48631 ] {cfb1fbae-6a20-4117-828f-ffdd688d754a} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:55500) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:07.983172 [ 48631 ] {cfb1fbae-6a20-4117-828f-ffdd688d754a} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:08.052548 [ 23639 ] {b52c93be-0803-499f-af0b-fb50891c0bfe} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:55522) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:08.052756 [ 23639 ] {b52c93be-0803-499f-af0b-fb50891c0bfe} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:08.207187 [ 22859 ] {010333f7-a4f1-4e58-b7eb-282b3e8b3d8f} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:55576) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:08.207296 [ 22859 ] {010333f7-a4f1-4e58-b7eb-282b3e8b3d8f} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:08.289104 [ 48631 ] {bdc8143e-a5c9-40e0-9abb-406bfc5c9eac} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:55604) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:08.289270 [ 48631 ] {bdc8143e-a5c9-40e0-9abb-406bfc5c9eac} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:08.462157 [ 22866 ] {f9d57838-f5cd-4f13-b45d-bba3b6528b59} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:55654) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:08.462387 [ 22866 ] {f9d57838-f5cd-4f13-b45d-bba3b6528b59} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:08.526202 [ 23610 ] {73a76e2a-2cc9-426b-bee9-0f944ea16767} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:55714) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:08.526360 [ 23610 ] {73a76e2a-2cc9-426b-bee9-0f944ea16767} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:08.778137 [ 48611 ] {b5c87209-8ceb-460d-b1ab-a4b4cd773932} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:55776) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:08.778342 [ 48611 ] {b5c87209-8ceb-460d-b1ab-a4b4cd773932} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:08.806846 [ 23621 ] {2f23030d-82af-449a-ae78-b72d165b9f49} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:55804) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:08.806954 [ 23621 ] {2f23030d-82af-449a-ae78-b72d165b9f49} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:08.982625 [ 48631 ] {f8210ac4-f7e3-4aa7-afc0-7f21d56abc8b} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46190) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:08.982758 [ 48631 ] {f8210ac4-f7e3-4aa7-afc0-7f21d56abc8b} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:09.048391 [ 23610 ] {ab89ecc5-afba-495f-b62c-0a5953a262d4} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46218) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:09.048543 [ 23610 ] {ab89ecc5-afba-495f-b62c-0a5953a262d4} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:09.219302 [ 14920 ] {0f53b1d7-07ef-4db1-93ce-6fffabef3117} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46290) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:09.219640 [ 14920 ] {0f53b1d7-07ef-4db1-93ce-6fffabef3117} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:09.292080 [ 48611 ] {8cb4d67e-6778-45e5-94b7-c8f01e2a4b34} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46334) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:09.292281 [ 48611 ] {8cb4d67e-6778-45e5-94b7-c8f01e2a4b34} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:09.435254 [ 48611 ] {d33aa71b-3920-416c-b53a-264eda307cb7} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46370) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:09.435381 [ 48611 ] {d33aa71b-3920-416c-b53a-264eda307cb7} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:09.497756 [ 48611 ] {3fd35a78-a448-4214-9980-48cfa8913e4f} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46398) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:09.497882 [ 48611 ] {3fd35a78-a448-4214-9980-48cfa8913e4f} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:09.658531 [ 23587 ] {3a9407bb-5f38-43b5-8e8e-f8f0ddeb20d0} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46442) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:09.658664 [ 23587 ] {3a9407bb-5f38-43b5-8e8e-f8f0ddeb20d0} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:09.702978 [ 23587 ] {7aaf1d2c-fe46-47a6-8bbc-14d40e1b524e} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46456) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:09.703117 [ 23587 ] {7aaf1d2c-fe46-47a6-8bbc-14d40e1b524e} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:09.896926 [ 23587 ] {21926f7f-7504-41cc-9231-cdbe4f3bc1f6} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46496) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:09.897086 [ 23587 ] {21926f7f-7504-41cc-9231-cdbe4f3bc1f6} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:09.903990 [ 14920 ] {33e4e72e-d10b-4b88-be85-7c5ba66d057a} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46512) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:09.904123 [ 14920 ] {33e4e72e-d10b-4b88-be85-7c5ba66d057a} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:10.153545 [ 23573 ] {24e19b25-fd16-4fd0-b33f-78c79112110e} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46566) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:10.153674 [ 23573 ] {24e19b25-fd16-4fd0-b33f-78c79112110e} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:10.171068 [ 23611 ] {3329ddc9-3cf5-4d82-81ab-f14a3a0c36fb} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46608) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:10.171210 [ 23611 ] {3329ddc9-3cf5-4d82-81ab-f14a3a0c36fb} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:10.363875 [ 23573 ] {82810d27-320c-4afb-a995-75b76c57a1a5} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46652) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:10.364011 [ 23573 ] {82810d27-320c-4afb-a995-75b76c57a1a5} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:10.389127 [ 23573 ] {9e908df5-7c0b-4b7f-8972-4400f8388b36} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46682) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:10.389237 [ 23573 ] {9e908df5-7c0b-4b7f-8972-4400f8388b36} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:10.573208 [ 3522 ] {dd22eb24-7b07-4b47-a666-24ba1c31bb40} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46732) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:10.573337 [ 3522 ] {dd22eb24-7b07-4b47-a666-24ba1c31bb40} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:10.631419 [ 23611 ] {5ea95aa6-6c84-4265-a7d4-73d6def83ac0} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46740) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:10.631614 [ 23611 ] {5ea95aa6-6c84-4265-a7d4-73d6def83ac0} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:10.782568 [ 14920 ] {7d8b3b95-016d-42d3-8f2a-182b6af37966} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46792) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:10.782698 [ 14920 ] {7d8b3b95-016d-42d3-8f2a-182b6af37966} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:10.895052 [ 23611 ] {f2e2d3ed-90a8-4505-8146-12296cb121cc} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46820) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:10.895254 [ 23611 ] {f2e2d3ed-90a8-4505-8146-12296cb121cc} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.045175 [ 23620 ] {c4a475e7-a38c-47d5-a38e-411f47ccbe87} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46878) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.045359 [ 23620 ] {c4a475e7-a38c-47d5-a38e-411f47ccbe87} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.108730 [ 23611 ] {cdc41dc3-5e2e-4e8a-83ea-154a9854ec15} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46894) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.108893 [ 23611 ] {cdc41dc3-5e2e-4e8a-83ea-154a9854ec15} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.232974 [ 23611 ] {301e4ad1-99ea-4681-88a2-bd3793b5331d} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46920) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.233158 [ 23611 ] {301e4ad1-99ea-4681-88a2-bd3793b5331d} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.307731 [ 22858 ] {80d0f3da-72f3-4fe2-b17e-4c2592bd4876} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46974) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.307891 [ 22858 ] {80d0f3da-72f3-4fe2-b17e-4c2592bd4876} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.474704 [ 23611 ] {40ad45a2-00ab-4e76-99d0-8a017bd4fcb5} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:46984) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.474870 [ 23611 ] {40ad45a2-00ab-4e76-99d0-8a017bd4fcb5} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.553488 [ 23611 ] {4564f1bc-eb2f-4467-ab1c-898db71a6c20} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:47014) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.553666 [ 23611 ] {4564f1bc-eb2f-4467-ab1c-898db71a6c20} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.733399 [ 48626 ] {cfb5fd4c-8f85-4597-803d-27c6cdf7cde6} executeQuery: Code: 403. DB::Exception: JOIN (SELECT _CAST(NULL, 'Nullable(Nothing)') AS a, 1 AS b FROM system.one AS __table2) AS __table1 ALL RIGHT JOIN (SELECT 1024 AS b FROM system.one AS __table4) AS __table3 ON 1 = __table1.b cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:47048) (comment: 01478_not_equi-join_on.sql) (in query: SELECT * FROM (SELECT NULL AS a, 1 AS b) AS foo RIGHT JOIN (SELECT 1024 AS b) AS bar ON 1 = foo.b;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.733692 [ 48626 ] {cfb5fd4c-8f85-4597-803d-27c6cdf7cde6} TCPHandler: Code: 403. DB::Exception: JOIN (SELECT _CAST(NULL, 'Nullable(Nothing)') AS a, 1 AS b FROM system.one AS __table2) AS __table1 ALL RIGHT JOIN (SELECT 1024 AS b FROM system.one AS __table4) AS __table3 ON 1 = __table1.b cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.733981 [ 22860 ] {17f7503b-211f-417d-8ade-62b3a1ad7853} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:47050) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.734107 [ 22860 ] {17f7503b-211f-417d-8ade-62b3a1ad7853} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.736983 [ 48626 ] {c96d53a0-6031-43fc-9659-e66d0d52a5c5} executeQuery: Code: 403. DB::Exception: JOIN (SELECT _CAST(NULL, 'Nullable(Nothing)') AS a, 1 AS b FROM system.one AS __table2) AS __table1 ALL RIGHT JOIN (SELECT 1024 AS b FROM system.one AS __table4) AS __table3 ON 1 = __table3.b cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:47048) (comment: 01478_not_equi-join_on.sql) (in query: SELECT * FROM (SELECT NULL AS a, 1 AS b) AS foo RIGHT JOIN (SELECT 1024 AS b) AS bar ON 1 = bar.b;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.737103 [ 48626 ] {c96d53a0-6031-43fc-9659-e66d0d52a5c5} TCPHandler: Code: 403. DB::Exception: JOIN (SELECT _CAST(NULL, 'Nullable(Nothing)') AS a, 1 AS b FROM system.one AS __table2) AS __table1 ALL RIGHT JOIN (SELECT 1024 AS b FROM system.one AS __table4) AS __table3 ON 1 = __table3.b cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.792103 [ 23620 ] {2c082a27-dbb6-439c-b5d4-32b95c547b0c} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:47056) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.792218 [ 23620 ] {2c082a27-dbb6-439c-b5d4-32b95c547b0c} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.934879 [ 23635 ] {21de81bb-4de4-45df-b7a9-20b6beb465dd} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:47104) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:11.935018 [ 23635 ] {21de81bb-4de4-45df-b7a9-20b6beb465dd} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.021234 [ 23635 ] {b7d96d7f-9ab9-43ff-a1ad-8638fb3bfb96} executeQuery: Code: 47. DB::Exception: JOIN test_p3ucpfkn.dist_table AS d GLOBAL ALL LEFT JOIN numbers(100) AS t USING (id) using identifier 'id' cannot be resolved from right table expression. In scope SELECT uniq(d.val) FROM dist_table AS d GLOBAL LEFT JOIN numbers(100) AS t USING (id). (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:47134) (comment: 01474_bad_global_join.sql) (in query: SELECT uniq(d.val) FROM dist_table AS d GLOBAL LEFT JOIN numbers(100) AS t USING id;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dffcf 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.021512 [ 23635 ] {b7d96d7f-9ab9-43ff-a1ad-8638fb3bfb96} TCPHandler: Code: 47. DB::Exception: JOIN test_p3ucpfkn.dist_table AS d GLOBAL ALL LEFT JOIN numbers(100) AS t USING (id) using identifier 'id' cannot be resolved from right table expression. In scope SELECT uniq(d.val) FROM dist_table AS d GLOBAL LEFT JOIN numbers(100) AS t USING (id). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000030919d63 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dffcf 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.092751 [ 23635 ] {b347371c-53a0-4a83-9c6f-64527d3ef490} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:47178) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000030f36f0f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.092991 [ 23635 ] {b347371c-53a0-4a83-9c6f-64527d3ef490} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000030f36f0f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.199770 [ 23635 ] {52a7244f-834e-4aee-a9f1-3b0026703be8} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:47186) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.199928 [ 23635 ] {52a7244f-834e-4aee-a9f1-3b0026703be8} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.287499 [ 12525 ] {90bd7eb5-78ae-4d9c-af58-8aaca3572993} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:47230) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.287663 [ 12525 ] {90bd7eb5-78ae-4d9c-af58-8aaca3572993} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.486901 [ 23620 ] {fe086f55-3958-4fac-b77d-44e9902216e7} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:47276) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.487050 [ 23620 ] {fe086f55-3958-4fac-b77d-44e9902216e7} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.531696 [ 23586 ] {64fbe507-d272-4d3f-b95b-140d701e8458} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:47312) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.531925 [ 23586 ] {64fbe507-d272-4d3f-b95b-140d701e8458} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.715531 [ 23586 ] {ba2eda07-9b7d-4cbc-89ef-4fdb5924016c} executeQuery: Code: 36. DB::Exception: Cannot specify codec for column type ALIAS. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:47342) (comment: 01462_test_codec_on_alias.sql) (in query: CREATE TABLE compression_codec_on_alias (`c0` ALIAS c1 CODEC(ZSTD), `c1` UInt64) ENGINE = MergeTree PARTITION BY c0 ORDER BY c1 SETTINGS index_granularity = 60295, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 208793786, compact_parts_max_bytes_to_buffer = 171189811, compact_parts_max_granules_to_buffer = 146, compact_parts_merge_max_bytes_to_prefetch_part = 4087023, merge_max_block_size = 11172, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 8058133065, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 6889061876, index_granularity_bytes = 9446061, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 47564, primary_key_compress_block_size = 26616), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:671: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b3fdd 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.715755 [ 23586 ] {ba2eda07-9b7d-4cbc-89ef-4fdb5924016c} TCPHandler: Code: 36. DB::Exception: Cannot specify codec for column type ALIAS. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:671: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b3fdd 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.753544 [ 23586 ] {819a1f61-e9c5-4624-a33a-db2c633e86c8} executeQuery: Code: 36. DB::Exception: Cannot specify codec for column type ALIAS. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:47342) (comment: 01462_test_codec_on_alias.sql) (in query: ALTER TABLE compression_codec_on_alias ADD COLUMN `c3` ALIAS c2 CODEC(ZSTD) AFTER c2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/AlterCommands.cpp:119: DB::AlterCommand::parse(DB::ASTAlterCommand const*) @ 0x00000000320784e2 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030794524 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.753743 [ 23586 ] {819a1f61-e9c5-4624-a33a-db2c633e86c8} TCPHandler: Code: 36. DB::Exception: Cannot specify codec for column type ALIAS. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/AlterCommands.cpp:119: DB::AlterCommand::parse(DB::ASTAlterCommand const*) @ 0x00000000320784e2 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030794524 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.799467 [ 48581 ] {cb6ba3dd-ebc9-4bff-9dab-4332b00ae10e} executeQuery: Code: 48. DB::Exception: Alter of type 'ADD_COLUMN' is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:47356) (comment: 01461_alter_table_function.sql) (in query: ALTER TABLE table_from_numbers ADD COLUMN col UInt8;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x000000002ec626db 4. ./build_docker/./src/Storages/IStorage.cpp:0: DB::IStorage::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000320df7e4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.799708 [ 48581 ] {cb6ba3dd-ebc9-4bff-9dab-4332b00ae10e} TCPHandler: Code: 48. DB::Exception: Alter of type 'ADD_COLUMN' is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x000000002ec626db 4. ./build_docker/./src/Storages/IStorage.cpp:0: DB::IStorage::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000320df7e4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.804551 [ 23586 ] {f4e012a8-314c-42d8-ac14-059617e75ac7} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:47422) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.804738 [ 23586 ] {f4e012a8-314c-42d8-ac14-059617e75ac7} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.810629 [ 48605 ] {77b8d31b-e26f-47d9-b75c-c8a3c361b41f} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:47434) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:12.810770 [ 48605 ] {77b8d31b-e26f-47d9-b75c-c8a3c361b41f} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.038847 [ 23590 ] {41389ff0-7220-48ab-bd77-73dbae80a32a} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:47496) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.038957 [ 23590 ] {41389ff0-7220-48ab-bd77-73dbae80a32a} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.076539 [ 23590 ] {f7387582-d520-42a3-ae3b-c3e3697633f6} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:47522) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.076695 [ 23590 ] {f7387582-d520-42a3-ae3b-c3e3697633f6} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.142230 [ 48581 ] {fe186825-802e-4427-bbab-c65f6bcd0ecd} executeQuery: Code: 36. DB::Exception: index_granularity_bytes: 1 is lower than specified min_index_granularity_bytes: 1024. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:47526) (comment: 01457_min_index_granularity_bytes_setting.sql) (in query: CREATE TABLE invalid_min_index_granularity_bytes_setting (`id` UInt64, `value` String) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity_bytes = 1, min_index_granularity_bytes = 1024, index_granularity = 12519, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 82, min_bytes_for_full_part_storage = 190621810, compact_parts_max_bytes_to_buffer = 297984548, compact_parts_max_granules_to_buffer = 251, compact_parts_merge_max_bytes_to_prefetch_part = 15399201, merge_max_block_size = 17193, old_parts_lifetime = 248., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 294440, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, concurrent_part_removal_threshold = 2, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 18624, primary_key_compress_block_size = 56961), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception const&, DB::SettingFieldNumber const&>(int, FormatStringHelperImpl const&>::type, std::type_identity const&>::type>, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&) @ 0x0000000032e410a2 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000032e17d6e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae56a9 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 8. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 10. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.142456 [ 48581 ] {fe186825-802e-4427-bbab-c65f6bcd0ecd} TCPHandler: Code: 36. DB::Exception: index_granularity_bytes: 1 is lower than specified min_index_granularity_bytes: 1024. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception const&, DB::SettingFieldNumber const&>(int, FormatStringHelperImpl const&>::type, std::type_identity const&>::type>, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&) @ 0x0000000032e410a2 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x0000000032e17d6e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae56a9 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 8. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 10. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.300395 [ 48606 ] {99bf61a2-0ada-4532-8c1b-0af93d02458b} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:47590) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.300511 [ 48606 ] {99bf61a2-0ada-4532-8c1b-0af93d02458b} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.308763 [ 48602 ] {d7983309-8360-49de-939f-c6bd7ae2e8c6} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:47594) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.308893 [ 48602 ] {d7983309-8360-49de-939f-c6bd7ae2e8c6} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.543547 [ 48605 ] {c7eb97a8-1996-442b-a04c-0e05fa752087} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:47702) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.543688 [ 48605 ] {c7eb97a8-1996-442b-a04c-0e05fa752087} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.631338 [ 23590 ] {9e7ecc77-c2a9-4759-b184-3260c0718b99} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:47726) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.631448 [ 23590 ] {9e7ecc77-c2a9-4759-b184-3260c0718b99} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.809238 [ 48605 ] {79d641e8-0285-4865-b481-79061df8b5e3} executeQuery: Code: 36. DB::Exception: Default codec cannot have any arguments, it's just an alias for codec specified in config.xml. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:47784) (comment: 01455_default_compression.sql) (in query: ALTER TABLE compress_table MODIFY COLUMN value2 CODEC(Default(5));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307efb98 5. ./build_docker/./src/Storages/AlterCommands.cpp:1338: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032086b83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.809257 [ 48606 ] {bdf101a8-486f-4a5a-9583-a6b77d889b4c} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:47826) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.809492 [ 48606 ] {bdf101a8-486f-4a5a-9583-a6b77d889b4c} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.809542 [ 48605 ] {79d641e8-0285-4865-b481-79061df8b5e3} TCPHandler: Code: 36. DB::Exception: Default codec cannot have any arguments, it's just an alias for codec specified in config.xml. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307efb98 5. ./build_docker/./src/Storages/AlterCommands.cpp:1338: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032086b83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.865535 [ 34946 ] {44ac0ecd-85ad-435b-a140-776860f6bc8f} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:47882) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:13.865667 [ 34946 ] {44ac0ecd-85ad-435b-a140-776860f6bc8f} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.065799 [ 34946 ] {b8d1ca95-ce39-4728-b04d-b8efb59574fa} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:47936) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.065925 [ 34946 ] {b8d1ca95-ce39-4728-b04d-b8efb59574fa} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.124717 [ 34946 ] {151e67a8-0ce0-47bd-af89-fe6f133e8894} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:47982) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.124878 [ 34946 ] {151e67a8-0ce0-47bd-af89-fe6f133e8894} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.152540 [ 48631 ] {896bc2cc-bbbc-4391-bfb0-dac43ca8c273} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:45588) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`number` AS `number` FROM `system`.`numbers` AS `__table1` LIMIT _CAST(100, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:629: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x0000000033fdc625 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:549: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000033fda3b6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033fd8140 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.152784 [ 48631 ] {896bc2cc-bbbc-4391-bfb0-dac43ca8c273} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:629: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x0000000033fdc625 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:549: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000033fda3b6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033fd8140 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.154964 [ 48606 ] {5883aeb5-5e31-45a9-a289-b451a4467196} executeQuery: Code: 158. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:629: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x0000000033fdc625 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:549: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000033fda3b6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033fd8140 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 : While executing Remote. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:47960) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM remote('127.0.0.1', system.numbers) LIMIT 100) SETTINGS max_rows_to_read_leaf=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:15:14.158907 [ 48606 ] {5883aeb5-5e31-45a9-a289-b451a4467196} TCPHandler: Code: 158. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:629: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x0000000033fdc625 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:549: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000033fda3b6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033fd8140 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 : While executing Remote. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:15:14.181530 [ 22863 ] {860d6776-b1d8-46f6-b9c0-5c4eab716a87} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. (TOO_MANY_BYTES) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:45594) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`number` AS `number` FROM `system`.`numbers` AS `__table1` LIMIT _CAST(100, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f44fd12 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f8a2 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f68 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.181664 [ 22863 ] {860d6776-b1d8-46f6-b9c0-5c4eab716a87} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f44fd12 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f8a2 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f68 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.182530 [ 48606 ] {c9f4bad3-b09e-4cc5-9a6e-af72b6a231a5} executeQuery: Code: 307. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f44fd12 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f8a2 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f68 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 : While executing Remote. (TOO_MANY_BYTES) (version 24.3.12.76.altinitystable) (from [::1]:47960) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM remote('127.0.0.1', system.numbers) LIMIT 100) SETTINGS max_bytes_to_read_leaf=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:15:14.182972 [ 48606 ] {c9f4bad3-b09e-4cc5-9a6e-af72b6a231a5} TCPHandler: Code: 307. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f44fd12 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f8a2 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f68 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 : While executing Remote. (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:15:14.283244 [ 34946 ] {b36d01a9-fb13-40da-b6b7-6ba073de2b86} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:40946) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`number` AS `number` FROM `system`.`numbers` AS `__table1` LIMIT _CAST(100, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:629: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x0000000033fdc625 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:549: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000033fda3b6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033fd8140 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.283380 [ 34946 ] {b36d01a9-fb13-40da-b6b7-6ba073de2b86} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:629: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x0000000033fdc625 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:549: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000033fda3b6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033fd8140 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.284308 [ 48606 ] {672aa36b-cf28-453f-a3a8-93b90bf89cc2} executeQuery: Code: 158. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:629: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x0000000033fdc625 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:549: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000033fda3b6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033fd8140 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 : While executing Remote. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:47960) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM remote('127.0.0.2', system.numbers) LIMIT 100) SETTINGS max_rows_to_read_leaf=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:15:14.285386 [ 48606 ] {672aa36b-cf28-453f-a3a8-93b90bf89cc2} TCPHandler: Code: 158. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:629: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x0000000033fdc625 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:549: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000033fda3b6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033fd8140 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 : While executing Remote. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:15:14.298807 [ 23610 ] {75cf955c-9dad-437f-a0ee-fd7657a9e385} executeQuery: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48052) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.298964 [ 23610 ] {75cf955c-9dad-437f-a0ee-fd7657a9e385} TCPHandler: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.313816 [ 22863 ] {9bc0597c-af43-4c2e-9179-fc2ead8c0d12} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. (TOO_MANY_BYTES) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:40954) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`number` AS `number` FROM `system`.`numbers` AS `__table1` LIMIT _CAST(100, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f44fd12 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f8a2 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f68 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.313937 [ 22863 ] {9bc0597c-af43-4c2e-9179-fc2ead8c0d12} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f44fd12 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f8a2 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f68 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.315355 [ 48606 ] {ee989815-59e8-49a0-bf21-895343a05570} executeQuery: Code: 307. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f44fd12 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f8a2 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f68 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 : While executing Remote. (TOO_MANY_BYTES) (version 24.3.12.76.altinitystable) (from [::1]:47960) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM remote('127.0.0.2', system.numbers) LIMIT 100) SETTINGS max_bytes_to_read_leaf=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:15:14.317773 [ 48606 ] {ee989815-59e8-49a0-bf21-895343a05570} TCPHandler: Code: 307. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f44fd12 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f8a2 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f68 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 : While executing Remote. (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:15:14.322319 [ 22866 ] {1a8aa7f1-9395-418c-9fe1-da8805fc1bbd} executeQuery: Code: 60. DB::Exception: Table `test_pmiaicjp`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48070) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:0: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002f7d7721 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:249: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f73f83c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f47348 7. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.322441 [ 22866 ] {1a8aa7f1-9395-418c-9fe1-da8805fc1bbd} TCPHandler: Code: 60. DB::Exception: Table `test_pmiaicjp`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:0: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002f7d7721 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:249: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f73f83c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f47348 7. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.342406 [ 22866 ] {038125c2-5c7a-4593-98f2-44f452bdcece} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48084) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.342632 [ 22866 ] {038125c2-5c7a-4593-98f2-44f452bdcece} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.431452 [ 5338 ] {38e5e7d3-f7bb-4d46-bc94-3ddbf154e666} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 40.00 thousand, current rows: 50.00 thousand. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:45714) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`date` AS `date` FROM `test_wwzo7p40`.`test_local` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f496c7 6. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.431739 [ 5338 ] {38e5e7d3-f7bb-4d46-bc94-3ddbf154e666} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 40.00 thousand, current rows: 50.00 thousand. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f496c7 6. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.445563 [ 34946 ] {afa936d4-792e-4420-8343-f7b8f02163c0} executeQuery: Code: 60. DB::Exception: Table test_pmiaicjp.t2 does not exist. Maybe you meant test_pmiaicjp.t1?. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48138) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.445741 [ 34946 ] {afa936d4-792e-4420-8343-f7b8f02163c0} TCPHandler: Code: 60. DB::Exception: Table test_pmiaicjp.t2 does not exist. Maybe you meant test_pmiaicjp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000181de381 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7611 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.448697 [ 1574 ] {d48b3991-943c-457b-9a07-21750753a5dc} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 40.00 thousand, current rows: 50.00 thousand. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:45396) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`date` AS `date` FROM `test_wwzo7p40`.`test_local` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f496c7 6. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.448923 [ 1574 ] {d48b3991-943c-457b-9a07-21750753a5dc} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 40.00 thousand, current rows: 50.00 thousand. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f496c7 6. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.450143 [ 48606 ] {60f0f831-e19b-4e60-ae1b-c5e1c0ab7775} executeQuery: Code: 158. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 40.00 thousand, current rows: 50.00 thousand. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f496c7 6. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 : While executing Remote. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:47960) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM test_distributed) SETTINGS max_rows_to_read_leaf = 40000;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:15:14.450543 [ 48606 ] {60f0f831-e19b-4e60-ae1b-c5e1c0ab7775} TCPHandler: Code: 158. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 40.00 thousand, current rows: 50.00 thousand. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f496c7 6. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 : While executing Remote. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:15:14.463059 [ 34946 ] {cd6378e1-421e-463b-be47-003bcd569ac6} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 39.06 KiB, current bytes: 97.66 KiB: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_BYTES) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:45636) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`date` AS `date` FROM `test_wwzo7p40`.`test_local` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f44fd12 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f8a2 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f68 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.463189 [ 34946 ] {cd6378e1-421e-463b-be47-003bcd569ac6} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 39.06 KiB, current bytes: 97.66 KiB: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f44fd12 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f8a2 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f68 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.463873 [ 22863 ] {0df6c779-3191-4844-9e12-2728da951c77} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 39.06 KiB, current bytes: 97.66 KiB: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_BYTES) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:40982) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`date` AS `date` FROM `test_wwzo7p40`.`test_local` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f44fd12 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f8a2 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f68 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.464020 [ 22863 ] {0df6c779-3191-4844-9e12-2728da951c77} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 39.06 KiB, current bytes: 97.66 KiB: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f44fd12 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f8a2 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f68 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.464864 [ 48606 ] {723b93d1-9a20-40c8-b392-eff6590311a0} executeQuery: Code: 307. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 39.06 KiB, current bytes: 97.66 KiB: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f44fd12 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f8a2 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f68 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 : While executing Remote. (TOO_MANY_BYTES) (version 24.3.12.76.altinitystable) (from [::1]:47960) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM test_distributed) SETTINGS max_bytes_to_read_leaf = 40000;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:15:14.465241 [ 48606 ] {723b93d1-9a20-40c8-b392-eff6590311a0} TCPHandler: Code: 307. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 39.06 KiB, current bytes: 97.66 KiB: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f44fd12 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f8a2 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f68 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 : While executing Remote. (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:15:14.479861 [ 48606 ] {425485b2-ec3a-4ecc-893a-bb67da60c2cf} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 60.00 thousand, current rows: 100.00 thousand: While executing Remote. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:47960) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM test_distributed) SETTINGS max_rows_to_read = 60000;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f3d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 9. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 10. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.482341 [ 48606 ] {425485b2-ec3a-4ecc-893a-bb67da60c2cf} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 60.00 thousand, current rows: 100.00 thousand: While executing Remote. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f3d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 9. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 10. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.486301 [ 22863 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:40994). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:14.511432 [ 48606 ] {5d0dca90-ee05-493d-8f3f-2dbf192ee747} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 97.66 KiB, current bytes: 195.31 KiB: While executing Remote. (TOO_MANY_BYTES) (version 24.3.12.76.altinitystable) (from [::1]:47960) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM test_distributed) SETTINGS max_bytes_to_read = 100000;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f44fd12 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f8a2 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f3d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 9. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 10. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.511827 [ 22863 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:41006). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000002487f287 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x000000002487e08f 5. DB::ReadBuffer::next() @ 0x0000000018778250 6. ./build_docker/./src/Server/TCPHandler.cpp:333: DB::TCPHandler::runImpl() @ 0x0000000033485401 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:14.520985 [ 48606 ] {5d0dca90-ee05-493d-8f3f-2dbf192ee747} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 97.66 KiB, current bytes: 195.31 KiB: While executing Remote. (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f44fd12 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f8a2 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f3d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 9. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 10. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.601632 [ 48611 ] {8e5e53dc-ecf3-44e0-bafb-6f2b9230a940} executeQuery: Code: 60. DB::Exception: Table test_pmiaicjp.t2 does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48226) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.601805 [ 48611 ] {8e5e53dc-ecf3-44e0-bafb-6f2b9230a940} TCPHandler: Code: 60. DB::Exception: Table test_pmiaicjp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.609757 [ 22866 ] {b9cad047-3b30-48d8-8657-36ad919757db} executeQuery: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48242) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.609912 [ 22866 ] {b9cad047-3b30-48d8-8657-36ad919757db} TCPHandler: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.614329 [ 48611 ] {369aa10c-492c-44c6-9d5c-606d9d234d30} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48248) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.614497 [ 48611 ] {369aa10c-492c-44c6-9d5c-606d9d234d30} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.668332 [ 48599 ] {b51a2e27-3955-4914-912f-342399b0fe05} executeQuery: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:48268) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.668466 [ 48599 ] {b51a2e27-3955-4914-912f-342399b0fe05} TCPHandler: Code: 57. DB::Exception: Table test_pmiaicjp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002f011fe3 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:726: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8b1dd 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f469e5 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.730382 [ 23621 ] {27fa72d0-bc41-4440-bea6-408573d07dd9} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48294) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000030f36f0f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.730547 [ 23621 ] {27fa72d0-bc41-4440-bea6-408573d07dd9} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000030f36f0f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.850156 [ 23587 ] {86f7caf1-c53c-4ad0-ba51-f6c7bee97943} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48348) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.850330 [ 23587 ] {86f7caf1-c53c-4ad0-ba51-f6c7bee97943} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.883425 [ 23621 ] {e9a7e145-0e9b-4666-9ba6-e1f3fce89713} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48372) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.883586 [ 23621 ] {e9a7e145-0e9b-4666-9ba6-e1f3fce89713} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.906387 [ 23621 ] {23dc2e21-f27c-42b1-abc1-5bd984796138} executeQuery: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48398) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.906567 [ 23621 ] {23dc2e21-f27c-42b1-abc1-5bd984796138} TCPHandler: Code: 60. DB::Exception: Table test_pmiaicjp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.917521 [ 23587 ] {f289854c-8fc9-4f22-8417-5b4ad6dd4d70} executeQuery: Code: 60. DB::Exception: Table test_pmiaicjp.t2 does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48412) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.917670 [ 23587 ] {f289854c-8fc9-4f22-8417-5b4ad6dd4d70} TCPHandler: Code: 60. DB::Exception: Table test_pmiaicjp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.927362 [ 23621 ] {6786b0ee-c76f-47b6-aad1-b1062bd68a40} executeQuery: Code: 60. DB::Exception: Table `test_pmiaicjp`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48420) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:0: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002f7d7721 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:249: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f73f83c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f47348 7. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:14.927516 [ 23621 ] {6786b0ee-c76f-47b6-aad1-b1062bd68a40} TCPHandler: Code: 60. DB::Exception: Table `test_pmiaicjp`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:0: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002f7d7721 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:249: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f73f83c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f47348 7. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:15.014945 [ 23621 ] {25a36650-cacc-40c2-b774-ede3b04f0579} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:48456) (comment: 01502_long_log_tinylog_deadlock_race.sh) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000030f36f0f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:15.015109 [ 23621 ] {25a36650-cacc-40c2-b774-ede3b04f0579} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000030f36f0f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.355389 [ 23587 ] {baacc928-8bdc-4a3f-b3dc-2ab08bad02ca} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -256, signed b = 9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT ignore(lcm(-256, 9223372036854775807)). (DECIMAL_OVERFLOW) (version 24.3.12.76.altinitystable) (from [::1]:48748) (comment: 01435_lcm_overflow.sql) (in query: SELECT ignore(lcm(-256, 9223372036854775807));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000001badb130 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(short, unsigned long) @ 0x000000001d86c797 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISE_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000001d90e667 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d8a0664 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d89e2e7 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d89c431 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:15:16.386905 [ 23622 ] {0c5469aa-2459-481d-9e1c-224129fc9669} executeQuery: Code: 43. DB::Exception: Illegal types Int32 and UInt256 of arguments of function greatest: In scope SELECT least(toUInt32(0), toInt256(0)), greatest(toInt32(0), toUInt256(0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:48760) (comment: 01440_big_int_least_greatest.sql) (in query: SELECT least(toUInt32(0), toInt256(0)), greatest(toInt32(0), toUInt256(0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001ccab4ef 5. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)1, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c97fe61 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.386941 [ 23587 ] {baacc928-8bdc-4a3f-b3dc-2ab08bad02ca} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -256, signed b = 9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT ignore(lcm(-256, 9223372036854775807)). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000001badb130 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(short, unsigned long) @ 0x000000001d86c797 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISE_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000001d90e667 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d8a0664 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d89e2e7 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d89c431 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:15:16.387162 [ 23622 ] {0c5469aa-2459-481d-9e1c-224129fc9669} TCPHandler: Code: 43. DB::Exception: Illegal types Int32 and UInt256 of arguments of function greatest: In scope SELECT least(toUInt32(0), toInt256(0)), greatest(toInt32(0), toUInt256(0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001ccab4ef 5. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)1, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c97fe61 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.415598 [ 23622 ] {697b2e2c-8537-4d2a-a7c2-e56847b8f939} executeQuery: Code: 43. DB::Exception: Illegal types Int32 and UInt256 of arguments of function least: In scope SELECT least(toInt32(0), toUInt256(0)), greatest(toInt32(0), toUInt256(0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:48760) (comment: 01440_big_int_least_greatest.sql) (in query: SELECT least(toInt32(0), toUInt256(0)), greatest(toInt32(0), toUInt256(0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001dcb0d2f 5. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)0, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001d986e01 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.415821 [ 23622 ] {697b2e2c-8537-4d2a-a7c2-e56847b8f939} TCPHandler: Code: 43. DB::Exception: Illegal types Int32 and UInt256 of arguments of function least: In scope SELECT least(toInt32(0), toUInt256(0)), greatest(toInt32(0), toUInt256(0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001dcb0d2f 5. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)0, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001d986e01 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.909737 [ 23597 ] {6e8f4116-1545-48b2-8741-d5342918c477} executeQuery: Code: 403. DB::Exception: JOIN (SELECT 1 AS a FROM system.one AS __table2) AS __table1 ALL INNER JOIN (SELECT 1 AS b FROM system.one AS __table4) AS __table3 ON arrayJoin(_CAST([1], 'Array(UInt8)')) = __table3.b cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:48858) (comment: 01429_join_on_error_messages.sql) (in query: SELECT 1 FROM (select 1 a) A JOIN (select 1 b) B ON (arrayJoin([1]) = B.b);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.909908 [ 23597 ] {6e8f4116-1545-48b2-8741-d5342918c477} TCPHandler: Code: 403. DB::Exception: JOIN (SELECT 1 AS a FROM system.one AS __table2) AS __table1 ALL INNER JOIN (SELECT 1 AS b FROM system.one AS __table4) AS __table3 ON arrayJoin(_CAST([1], 'Array(UInt8)')) = __table3.b cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.914501 [ 23597 ] {ea763fdd-6e3b-4158-bca7-a5cf061cf0c5} executeQuery: Code: 403. DB::Exception: JOIN (SELECT 1 AS a FROM system.one AS __table2) AS __table1 ALL INNER JOIN (SELECT 1 AS b FROM system.one AS __table4) AS __table3 ON __table1.a = arrayJoin(_CAST([1], 'Array(UInt8)')) cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:48858) (comment: 01429_join_on_error_messages.sql) (in query: SELECT 1 FROM (select 1 a) A JOIN (select 1 b) B ON (A.a = arrayJoin([1]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.914667 [ 23597 ] {ea763fdd-6e3b-4158-bca7-a5cf061cf0c5} TCPHandler: Code: 403. DB::Exception: JOIN (SELECT 1 AS a FROM system.one AS __table2) AS __table1 ALL INNER JOIN (SELECT 1 AS b FROM system.one AS __table4) AS __table3 ON __table1.a = arrayJoin(_CAST([1], 'Array(UInt8)')) cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.941897 [ 23597 ] {8c9d6fa6-5665-477e-85d0-b77e4a13355d} executeQuery: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 1, should be 2: In scope SELECT 1 FROM (SELECT 1 AS a) AS A INNER JOIN (SELECT 1 AS b) AS B ON equals(a). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:48858) (comment: 01429_join_on_error_messages.sql) (in query: SELECT 1 FROM (select 1 a) A JOIN (select 1 b) B ON equals(a);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dcf56 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.942103 [ 23597 ] {8c9d6fa6-5665-477e-85d0-b77e4a13355d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 1, should be 2: In scope SELECT 1 FROM (SELECT 1 AS a) AS A INNER JOIN (SELECT 1 AS b) AS B ON equals(a). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dcf56 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.944395 [ 23597 ] {24766c60-59e5-408e-a52e-3e591fb01ecb} executeQuery: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 1, should be 2: In scope SELECT 1 FROM (SELECT 1 AS a) AS A INNER JOIN (SELECT 1 AS b) AS B ON less(a). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:48858) (comment: 01429_join_on_error_messages.sql) (in query: SELECT 1 FROM (select 1 a) A JOIN (select 1 b) B ON less(a);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dcf56 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.944533 [ 23597 ] {24766c60-59e5-408e-a52e-3e591fb01ecb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 1, should be 2: In scope SELECT 1 FROM (SELECT 1 AS a) AS A INNER JOIN (SELECT 1 AS b) AS B ON less(a). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dcf56 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.948090 [ 23597 ] {7e498018-a959-4f8d-b9a7-bab7e3155475} executeQuery: Code: 403. DB::Exception: JOIN (SELECT 1 AS a FROM system.one AS __table2) AS __table1 ALL INNER JOIN (SELECT 1 AS b FROM system.one AS __table4) AS __table3 ON (__table1.a = __table3.b) AND (__table1.a > __table3.b) join expression contains column from left and right table. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:48858) (comment: 01429_join_on_error_messages.sql) (in query: SELECT 1 FROM (select 1 a) A JOIN (select 1 b) B ON a = b AND a > b;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::extractJoinTableSideFromExpression(DB::IQueryTreeNode const*, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&) @ 0x000000003109d6ca 5. ./build_docker/./src/Planner/PlannerJoins.cpp:364: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bd25 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bf95 7. ./build_docker/./src/Planner/PlannerJoins.cpp:511: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310938de 8. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.948228 [ 23597 ] {7e498018-a959-4f8d-b9a7-bab7e3155475} TCPHandler: Code: 403. DB::Exception: JOIN (SELECT 1 AS a FROM system.one AS __table2) AS __table1 ALL INNER JOIN (SELECT 1 AS b FROM system.one AS __table4) AS __table3 ON (__table1.a = __table3.b) AND (__table1.a > __table3.b) join expression contains column from left and right table. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::extractJoinTableSideFromExpression(DB::IQueryTreeNode const*, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&) @ 0x000000003109d6ca 5. ./build_docker/./src/Planner/PlannerJoins.cpp:364: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bd25 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bf95 7. ./build_docker/./src/Planner/PlannerJoins.cpp:511: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310938de 8. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.951767 [ 23597 ] {e436eff8-e767-4df7-83fe-f289b336cc89} executeQuery: Code: 403. DB::Exception: JOIN (SELECT 1 AS a FROM system.one AS __table2) AS __table1 ALL INNER JOIN (SELECT 1 AS b FROM system.one AS __table4) AS __table3 ON (__table1.a = __table3.b) AND (__table1.a < __table3.b) join expression contains column from left and right table. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:48858) (comment: 01429_join_on_error_messages.sql) (in query: SELECT 1 FROM (select 1 a) A JOIN (select 1 b) B ON a = b AND a < b;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::extractJoinTableSideFromExpression(DB::IQueryTreeNode const*, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&) @ 0x000000003109d6ca 5. ./build_docker/./src/Planner/PlannerJoins.cpp:364: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bd25 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bf95 7. ./build_docker/./src/Planner/PlannerJoins.cpp:511: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310938de 8. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.951904 [ 23597 ] {e436eff8-e767-4df7-83fe-f289b336cc89} TCPHandler: Code: 403. DB::Exception: JOIN (SELECT 1 AS a FROM system.one AS __table2) AS __table1 ALL INNER JOIN (SELECT 1 AS b FROM system.one AS __table4) AS __table3 ON (__table1.a = __table3.b) AND (__table1.a < __table3.b) join expression contains column from left and right table. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::extractJoinTableSideFromExpression(DB::IQueryTreeNode const*, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&) @ 0x000000003109d6ca 5. ./build_docker/./src/Planner/PlannerJoins.cpp:364: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bd25 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bf95 7. ./build_docker/./src/Planner/PlannerJoins.cpp:511: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310938de 8. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.954709 [ 23597 ] {691cc2fb-2960-4ffa-86ef-19eb2a4e2d9e} executeQuery: Code: 403. DB::Exception: JOIN (SELECT 1 AS a FROM system.one AS __table2) AS __table1 ALL INNER JOIN (SELECT 1 AS b FROM system.one AS __table4) AS __table3 ON (__table1.a = __table3.b) AND (__table1.a >= __table3.b) join expression contains column from left and right table. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:48858) (comment: 01429_join_on_error_messages.sql) (in query: SELECT 1 FROM (select 1 a) A JOIN (select 1 b) B ON a = b AND a >= b;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::extractJoinTableSideFromExpression(DB::IQueryTreeNode const*, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&) @ 0x000000003109d6ca 5. ./build_docker/./src/Planner/PlannerJoins.cpp:364: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bd25 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bf95 7. ./build_docker/./src/Planner/PlannerJoins.cpp:511: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310938de 8. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.954860 [ 23597 ] {691cc2fb-2960-4ffa-86ef-19eb2a4e2d9e} TCPHandler: Code: 403. DB::Exception: JOIN (SELECT 1 AS a FROM system.one AS __table2) AS __table1 ALL INNER JOIN (SELECT 1 AS b FROM system.one AS __table4) AS __table3 ON (__table1.a = __table3.b) AND (__table1.a >= __table3.b) join expression contains column from left and right table. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::extractJoinTableSideFromExpression(DB::IQueryTreeNode const*, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&) @ 0x000000003109d6ca 5. ./build_docker/./src/Planner/PlannerJoins.cpp:364: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bd25 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bf95 7. ./build_docker/./src/Planner/PlannerJoins.cpp:511: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310938de 8. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.957707 [ 23597 ] {5e9b90ec-a789-4bd7-b175-c33f53445a1e} executeQuery: Code: 403. DB::Exception: JOIN (SELECT 1 AS a FROM system.one AS __table2) AS __table1 ALL INNER JOIN (SELECT 1 AS b FROM system.one AS __table4) AS __table3 ON (__table1.a = __table3.b) AND (__table1.a <= __table3.b) join expression contains column from left and right table. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:48858) (comment: 01429_join_on_error_messages.sql) (in query: SELECT 1 FROM (select 1 a) A JOIN (select 1 b) B ON a = b AND a <= b;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::extractJoinTableSideFromExpression(DB::IQueryTreeNode const*, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&) @ 0x000000003109d6ca 5. ./build_docker/./src/Planner/PlannerJoins.cpp:364: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bd25 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bf95 7. ./build_docker/./src/Planner/PlannerJoins.cpp:511: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310938de 8. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.957840 [ 23597 ] {5e9b90ec-a789-4bd7-b175-c33f53445a1e} TCPHandler: Code: 403. DB::Exception: JOIN (SELECT 1 AS a FROM system.one AS __table2) AS __table1 ALL INNER JOIN (SELECT 1 AS b FROM system.one AS __table4) AS __table3 ON (__table1.a = __table3.b) AND (__table1.a <= __table3.b) join expression contains column from left and right table. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::extractJoinTableSideFromExpression(DB::IQueryTreeNode const*, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&) @ 0x000000003109d6ca 5. ./build_docker/./src/Planner/PlannerJoins.cpp:364: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bd25 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bf95 7. ./build_docker/./src/Planner/PlannerJoins.cpp:511: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310938de 8. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.977737 [ 23597 ] {423630f6-37fc-499d-a3cf-8b69d10f4d5e} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:48858) (comment: 01429_join_on_error_messages.sql) (in query: SELECT 1 FROM (select 1 a) A JOIN (select 1 b, 1 c) B ON a = b OR a = c;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109afc1 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.977892 [ 23597 ] {423630f6-37fc-499d-a3cf-8b69d10f4d5e} TCPHandler: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109afc1 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.981970 [ 23597 ] {9b9b29e4-a2d4-4e09-afba-3c10b77672eb} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:48858) (comment: 01429_join_on_error_messages.sql) (in query: SELECT 1 FROM (select 1 a) A JOIN (select 1 b, 1 c) B ON a = b OR a = c;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109afc1 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.982101 [ 23597 ] {9b9b29e4-a2d4-4e09-afba-3c10b77672eb} TCPHandler: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109afc1 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.986813 [ 23597 ] {fdbce971-78be-4e10-af42-ae198aa2a5a2} executeQuery: Code: 403. DB::Exception: JOIN (SELECT 1 AS a, 1 AS b, 1 AS c FROM system.one AS __table2) AS __table1 ALL INNER JOIN (SELECT 1 AS a, 1 AS b, 1 AS c FROM system.one AS __table4) AS __table3 ON (__table1.a = __table3.a) AND ((__table1.b > 0) OR (__table3.b > 0)) join expression contains column from left and right table. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:48858) (comment: 01429_join_on_error_messages.sql) (in query: -- conditions for different table joined via OR SELECT * FROM (SELECT 1 AS a, 1 AS b, 1 AS c) AS t1 INNER JOIN (SELECT 1 AS a, 1 AS b, 1 AS c) AS t2 ON t1.a = t2.a AND (t1.b > 0 OR t2.b > 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::extractJoinTableSideFromExpression(DB::IQueryTreeNode const*, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&) @ 0x000000003109d6ca 5. ./build_docker/./src/Planner/PlannerJoins.cpp:364: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bd25 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bf95 7. ./build_docker/./src/Planner/PlannerJoins.cpp:511: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310938de 8. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:16.987051 [ 23597 ] {fdbce971-78be-4e10-af42-ae198aa2a5a2} TCPHandler: Code: 403. DB::Exception: JOIN (SELECT 1 AS a, 1 AS b, 1 AS c FROM system.one AS __table2) AS __table1 ALL INNER JOIN (SELECT 1 AS a, 1 AS b, 1 AS c FROM system.one AS __table4) AS __table3 ON (__table1.a = __table3.a) AND ((__table1.b > 0) OR (__table3.b > 0)) join expression contains column from left and right table. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::extractJoinTableSideFromExpression(DB::IQueryTreeNode const*, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&) @ 0x000000003109d6ca 5. ./build_docker/./src/Planner/PlannerJoins.cpp:364: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bd25 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::(anonymous namespace)::buildJoinClause(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x000000003109bf95 7. ./build_docker/./src/Planner/PlannerJoins.cpp:511: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310938de 8. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:17.458075 [ 23611 ] {009777c2-cce9-461a-ab28-531ed316eb36} executeQuery: Code: 43. DB::Exception: Aggregation 'nothingNullMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:48986) (comment: 01422_map_skip_null.sql) (in query: select minMap(arrayJoin([([1], [null]), ([1], [null])]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:454: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028eac023 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:17.458267 [ 23611 ] {009777c2-cce9-461a-ab28-531ed316eb36} TCPHandler: Code: 43. DB::Exception: Aggregation 'nothingNullMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:454: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028eac023 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:17.460801 [ 23611 ] {92b16799-3326-4df0-b0b0-e7ae16d2aa4f} executeQuery: Code: 43. DB::Exception: Aggregation 'nothingNullMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:48986) (comment: 01422_map_skip_null.sql) (in query: select maxMap(arrayJoin([([1], [null]), ([1], [null])]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:454: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028eac023 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:17.461212 [ 23611 ] {92b16799-3326-4df0-b0b0-e7ae16d2aa4f} TCPHandler: Code: 43. DB::Exception: Aggregation 'nothingNullMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:454: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028eac023 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:17.463023 [ 23611 ] {9d2b8002-4c2f-4af3-bfd6-fa8208ddd7aa} executeQuery: Code: 43. DB::Exception: Aggregation 'nothingNullMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:48986) (comment: 01422_map_skip_null.sql) (in query: select sumMap(arrayJoin([([1], [null]), ([1], [null])]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:454: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028eac023 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:17.463337 [ 23611 ] {9d2b8002-4c2f-4af3-bfd6-fa8208ddd7aa} TCPHandler: Code: 43. DB::Exception: Aggregation 'nothingNullMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:454: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028eac023 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:17.487594 [ 23611 ] {934205fd-560b-45f1-888c-e1df03b07815} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:48986) (comment: 01422_map_skip_null.sql) (in query: select sumMapWithOverflow(arrayJoin([([1], [null]), ([1], [null])]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:0: DB::registerAggregateFunctionSumMap(DB::AggregateFunctionFactory&)::$_3::operator()(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) const @ 0x00000000275794f4 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:17.487829 [ 23611 ] {934205fd-560b-45f1-888c-e1df03b07815} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:0: DB::registerAggregateFunctionSumMap(DB::AggregateFunctionFactory&)::$_3::operator()(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) const @ 0x00000000275794f4 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:17.974792 [ 23611 ] {b9480d35-162a-4606-be24-0b327b78853c} executeQuery: Code: 73. DB::Exception: Unknown format aaa: In scope SELECT formatRow('aaa', *) FROM numbers(3). (UNKNOWN_FORMAT) (version 24.3.12.76.altinitystable) (from [::1]:49044) (comment: 01420_format_row.gen.sql) (in query: -- unknown format select formatRow('aaa', *) from numbers(3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Formats/FormatFactory.cpp:864: DB::FormatFactory::checkFormatName(String const&) const @ 0x00000000334f0c2a 5. DB::(anonymous namespace)::FormatRowOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000001b946f9e 6. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844964 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:17.975004 [ 23611 ] {b9480d35-162a-4606-be24-0b327b78853c} TCPHandler: Code: 73. DB::Exception: Unknown format aaa: In scope SELECT formatRow('aaa', *) FROM numbers(3). (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Formats/FormatFactory.cpp:864: DB::FormatFactory::checkFormatName(String const&) const @ 0x00000000334f0c2a 5. DB::(anonymous namespace)::FormatRowOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000001b946f9e 6. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844964 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:18.670456 [ 23620 ] {2b59c63c-7e4e-4ab2-9d98-36aa481105e0} executeQuery: Code: 115. DB::Exception: Unknown setting 'custom_e': In scope SELECT getSetting('custom_e') AS v, toTypeName(v). (UNKNOWN_SETTING) (version 24.3.12.76.altinitystable) (from [::1]:49204) (comment: 01418_custom_settings.sql) (in query: SELECT getSetting('custom_e') as v, toTypeName(v);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Core/BaseSettings.cpp:0: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002f108a6e 5. DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000001bb15816 6. DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000001bb1560d 7. DB::(anonymous namespace)::FunctionGetSetting::getValue(std::vector> const&) const @ 0x000000001bb151bc 8. DB::(anonymous namespace)::FunctionGetSetting::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bb14fb1 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:18.670664 [ 23620 ] {2b59c63c-7e4e-4ab2-9d98-36aa481105e0} TCPHandler: Code: 115. DB::Exception: Unknown setting 'custom_e': In scope SELECT getSetting('custom_e') AS v, toTypeName(v). (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Core/BaseSettings.cpp:0: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002f108a6e 5. DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000001bb15816 6. DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000001bb1560d 7. DB::(anonymous namespace)::FunctionGetSetting::getValue(std::vector> const&) const @ 0x000000001bb151bc 8. DB::(anonymous namespace)::FunctionGetSetting::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bb14fb1 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:18.693440 [ 23620 ] {7739435b-6fc9-45c8-b3c6-c205f8e9f2ee} executeQuery: Code: 115. DB::Exception: Setting invalid_custom is neither a builtin setting nor started with the prefix 'SQL_' or 'custom_' registered for user-defined settings. (UNKNOWN_SETTING) (version 24.3.12.76.altinitystable) (from [::1]:49204) (comment: 01418_custom_settings.sql) (in query: SET invalid_custom = 8;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::CustomSettingsPrefixes::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x000000002ecdd208 5. ./build_docker/./src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a07 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002eed0ee2 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002fc65656 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x00000000310cdc3d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:18.693575 [ 23620 ] {7739435b-6fc9-45c8-b3c6-c205f8e9f2ee} TCPHandler: Code: 115. DB::Exception: Setting invalid_custom is neither a builtin setting nor started with the prefix 'SQL_' or 'custom_' registered for user-defined settings. (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::CustomSettingsPrefixes::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x000000002ecdd208 5. ./build_docker/./src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002eed0a07 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002eed0ee2 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002fc65656 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x00000000310cdc3d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:18.719680 [ 23620 ] {b8dc165e-0263-44cb-a5d8-1e121702afca} executeQuery: Code: 115. DB::Exception: Unknown setting 'custom_f': In scope SELECT getSetting('custom_f') AS v, toTypeName(v). (UNKNOWN_SETTING) (version 24.3.12.76.altinitystable) (from [::1]:49204) (comment: 01418_custom_settings.sql) (in query: SELECT getSetting('custom_f') as v, toTypeName(v);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Core/BaseSettings.cpp:0: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002f108a6e 5. DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000001bb15816 6. DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000001bb1560d 7. DB::(anonymous namespace)::FunctionGetSetting::getValue(std::vector> const&) const @ 0x000000001bb151bc 8. DB::(anonymous namespace)::FunctionGetSetting::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bb14fb1 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:18.719793 [ 23620 ] {b8dc165e-0263-44cb-a5d8-1e121702afca} TCPHandler: Code: 115. DB::Exception: Unknown setting 'custom_f': In scope SELECT getSetting('custom_f') AS v, toTypeName(v). (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Core/BaseSettings.cpp:0: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002f108a6e 5. DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000001bb15816 6. DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000001bb1560d 7. DB::(anonymous namespace)::FunctionGetSetting::getValue(std::vector> const&) const @ 0x000000001bb151bc 8. DB::(anonymous namespace)::FunctionGetSetting::getReturnTypeImpl(std::vector> const&) const @ 0x000000001bb14fb1 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:19.052555 [ 1574 ] {9364aa1c-711f-4c84-9800-8af3cafe2b29} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 24.3.12.76.altinitystable) (from [::1]:40196) (comment: 01443_merge_truncate_long.sh) (in query: OPTIMIZE TABLE t FINAL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1145: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, String&, bool) @ 0x0000000033097b5d 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1587: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000330a33f0 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:19.053344 [ 1574 ] {9364aa1c-711f-4c84-9800-8af3cafe2b29} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1145: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, String&, bool) @ 0x0000000033097b5d 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1587: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000330a33f0 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:19.716972 [ 1331 ] {e11b89e0-b900-48ad-9ce1-d7daa57e81b5::20191002_2_2_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/e11/e11b89e0-b900-48ad-9ce1-d7daa57e81b5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) 2025.03.05 21:15:19.769810 [ 23498 ] {aad075bd-9caa-48d3-88ef-3b772e1b0bc2} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '20191002_2_2_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/e11/e11b89e0-b900-48ad-9ce1-d7daa57e81b5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable)'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.3.12.76.altinitystable) (from [::1]:40492) (comment: 01414_mutations_and_errors.sql) (in query: ALTER TABLE mutation_table MODIFY COLUMN value UInt64 SETTINGS mutations_sync = 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000330829c0 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795294 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:19.769826 [ 1331 ] {e11b89e0-b900-48ad-9ce1-d7daa57e81b5::20191002_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/e11/e11b89e0-b900-48ad-9ce1-d7daa57e81b5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182e9b67 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182e12ef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 19. ./contrib/llvm-project/libcxx/include/vector:537: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002fdbd37f 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000003172a443 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:265: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000032db324b 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:240: DB::MergeTreeSequentialSource::generate() @ 0x0000000032dd47d7 23. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 27. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000032e803d8 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1204: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000032eab8f4 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:19.770109 [ 23498 ] {aad075bd-9caa-48d3-88ef-3b772e1b0bc2} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '20191002_2_2_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/e11/e11b89e0-b900-48ad-9ce1-d7daa57e81b5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable)'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000330829c0 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795294 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:19.773819 [ 1333 ] {e11b89e0-b900-48ad-9ce1-d7daa57e81b5::20191002_2_2_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/e11/e11b89e0-b900-48ad-9ce1-d7daa57e81b5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) 2025.03.05 21:15:19.774327 [ 1333 ] {e11b89e0-b900-48ad-9ce1-d7daa57e81b5::20191002_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/e11/e11b89e0-b900-48ad-9ce1-d7daa57e81b5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182e9b67 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182e12ef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 19. ./contrib/llvm-project/libcxx/include/vector:537: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002fdbd37f 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000003172a443 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:265: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000032db324b 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:240: DB::MergeTreeSequentialSource::generate() @ 0x0000000032dd47d7 23. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 27. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000033573f12 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000032e803d8 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1204: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000032eab8f4 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:19.812520 [ 23498 ] {07a43638-6d12-423d-9d5d-89394b0ed7cf} executeQuery: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/e11/e11b89e0-b900-48ad-9ce1-d7daa57e81b5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:40492) (comment: 01414_mutations_and_errors.sql) (in query: SELECT distinct(value) FROM mutation_table ORDER BY value;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182e9b67 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182e12ef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 19. ./contrib/llvm-project/libcxx/include/vector:537: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002fdbd37f 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000003172a443 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:265: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000032db324b 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1051: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df6096 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:164: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000032e04f6f 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000033f65c94 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:139: DB::MergeTreeSelectProcessor::read() @ 0x0000000032de396f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:0: DB::MergeTreeSource::tryGenerate() @ 0x0000000033fb1d35 27. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 31. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 2025.03.05 21:15:19.830784 [ 48624 ] {c5679247-b29a-407b-a206-d811ee21b258} executeQuery: Code: 524. DB::Exception: The following alter commands: 'MODIFY COLUMN `value3` UInt64' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:40532) (comment: 01413_allow_non_metadata_alters.sql) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value3 UInt64;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44a0c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:19.830787 [ 23498 ] {07a43638-6d12-423d-9d5d-89394b0ed7cf} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/e11/e11b89e0-b900-48ad-9ce1-d7daa57e81b5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000182e9b67 6. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000182e12ef 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 13. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 19. ./contrib/llvm-project/libcxx/include/vector:537: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002fdbd37f 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000003172a443 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:265: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000032db324b 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1051: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df6096 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:164: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000032e04f6f 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000033f65c94 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:139: DB::MergeTreeSelectProcessor::read() @ 0x0000000032de396f 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:0: DB::MergeTreeSource::tryGenerate() @ 0x0000000033fb1d35 27. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 31. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 2025.03.05 21:15:19.830997 [ 48624 ] {c5679247-b29a-407b-a206-d811ee21b258} TCPHandler: Code: 524. DB::Exception: The following alter commands: 'MODIFY COLUMN `value3` UInt64' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44a0c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:19.833040 [ 48624 ] {6c85e34e-c673-49a1-b53a-8fae6b8661cd} executeQuery: Code: 524. DB::Exception: The following alter commands: 'MODIFY COLUMN `value1` UInt32' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:40532) (comment: 01413_allow_non_metadata_alters.sql) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value1 UInt32;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44a0c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:19.833144 [ 48624 ] {6c85e34e-c673-49a1-b53a-8fae6b8661cd} TCPHandler: Code: 524. DB::Exception: The following alter commands: 'MODIFY COLUMN `value1` UInt32' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44a0c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:19.834468 [ 48624 ] {996451da-4671-460a-916d-a76343eb343c} executeQuery: Code: 524. DB::Exception: The following alter commands: 'MODIFY COLUMN `value4` Date' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:40532) (comment: 01413_allow_non_metadata_alters.sql) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value4 Date;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44a0c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:19.834563 [ 48624 ] {996451da-4671-460a-916d-a76343eb343c} TCPHandler: Code: 524. DB::Exception: The following alter commands: 'MODIFY COLUMN `value4` Date' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44a0c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:19.835742 [ 48624 ] {805c3cc8-245b-46bc-9abf-8f2870e17d4e} executeQuery: Code: 524. DB::Exception: The following alter commands: 'DROP COLUMN value4' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:40532) (comment: 01413_allow_non_metadata_alters.sql) (in query: ALTER TABLE non_metadata_alters DROP COLUMN value4;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44a0c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:19.835893 [ 48624 ] {805c3cc8-245b-46bc-9abf-8f2870e17d4e} TCPHandler: Code: 524. DB::Exception: The following alter commands: 'DROP COLUMN value4' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44a0c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:19.837265 [ 48624 ] {ff8abe17-9026-4a4e-b51d-242ad325b7d4} executeQuery: Code: 524. DB::Exception: The following alter commands: 'MODIFY COLUMN `value2` Enum8('x' = 5, 'y' = 6)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:40532) (comment: 01413_allow_non_metadata_alters.sql) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value2 Enum8('x' = 5, 'y' = 6);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44a0c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:19.837388 [ 48624 ] {ff8abe17-9026-4a4e-b51d-242ad325b7d4} TCPHandler: Code: 524. DB::Exception: The following alter commands: 'MODIFY COLUMN `value2` Enum8('x' = 5, 'y' = 6)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44a0c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:19.838731 [ 48624 ] {bfa6a3cd-5c01-49cd-8484-19ef4a39b9a7} executeQuery: Code: 524. DB::Exception: The following alter commands: 'RENAME COLUMN value4 TO renamed_value4' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:40532) (comment: 01413_allow_non_metadata_alters.sql) (in query: ALTER TABLE non_metadata_alters RENAME COLUMN value4 TO renamed_value4;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44a0c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:19.838837 [ 48624 ] {bfa6a3cd-5c01-49cd-8484-19ef4a39b9a7} TCPHandler: Code: 524. DB::Exception: The following alter commands: 'RENAME COLUMN value4 TO renamed_value4' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44a0c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:19.840232 [ 48624 ] {6ab42843-3b7f-409a-9f0d-77a69c39116b} executeQuery: Code: 524. DB::Exception: The following alter commands: 'MATERIALIZE TTL' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:40532) (comment: 01413_allow_non_metadata_alters.sql) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value3 UInt16 TTL value5 + INTERVAL 5 DAY;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44a0c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:19.840317 [ 48624 ] {6ab42843-3b7f-409a-9f0d-77a69c39116b} TCPHandler: Code: 524. DB::Exception: The following alter commands: 'MATERIALIZE TTL' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44a0c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:20.437898 [ 48603 ] {bc78cb5e-a556-474a-b88d-3cf96db31f0e} executeQuery: Code: 69. DB::Exception: A call to function range would produce 18446744073709550590 array elements, which is greater than the allowed maximum of 500000000: In scope SELECT range(1025, 18446744073709551615, 1). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:40668) (comment: 01408_range_overflow.sql) (in query: SELECT range(1025, 18446744073709551615, 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. COW::immutable_ptr DB::FunctionRange::executeGeneric(DB::IColumn const*, DB::IColumn const*, DB::IColumn const*, unsigned long) const @ 0x00000000245d2a06 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000245ab401 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:20.438109 [ 48603 ] {bc78cb5e-a556-474a-b88d-3cf96db31f0e} TCPHandler: Code: 69. DB::Exception: A call to function range would produce 18446744073709550590 array elements, which is greater than the allowed maximum of 500000000: In scope SELECT range(1025, 18446744073709551615, 1). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. COW::immutable_ptr DB::FunctionRange::executeGeneric(DB::IColumn const*, DB::IColumn const*, DB::IColumn const*, unsigned long) const @ 0x00000000245d2a06 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000245ab401 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:20.700104 [ 48624 ] {b0ef10f9-4fd3-4710-aef8-dfaab2b4188f} executeQuery: Code: 43. DB::Exception: Unsupported types for IN. First argument type Tuple(Nothing, Nothing). Second argument type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:40742) (comment: 01407_lambda_arrayJoin.sql) (in query: SELECT * FROM system.one ARRAY JOIN arrayFilter((a) -> ((a, arrayJoin([])) IN (NULL)), []) AS arr_x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/SetUtils.cpp:0: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000030945f55 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103c1c6 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 7. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 11. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 12. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 13. ./build_docker/./src/Planner/CollectSets.cpp:121: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003103b763 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008ed2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:20.700325 [ 48624 ] {b0ef10f9-4fd3-4710-aef8-dfaab2b4188f} TCPHandler: Code: 43. DB::Exception: Unsupported types for IN. First argument type Tuple(Nothing, Nothing). Second argument type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Analyzer/SetUtils.cpp:0: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000030945f55 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103c1c6 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 7. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 11. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 12. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 13. ./build_docker/./src/Planner/CollectSets.cpp:121: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003103b763 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008ed2 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 20. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 25. ? @ 0x00007fe1df9bbac3 26. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:20.772017 [ 48624 ] {79afcfaf-3e6f-4657-80ce-af95fb0d26ea} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:40776) (comment: 01397_in_bad_arguments.sql) (in query: select in((1, 1, 1, 1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5594: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a98c7 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:20.772191 [ 48624 ] {79afcfaf-3e6f-4657-80ce-af95fb0d26ea} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5594: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a98c7 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:20.774329 [ 48624 ] {ff0bc84d-f974-4ca4-b0c5-3b5b4399e061} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:40776) (comment: 01397_in_bad_arguments.sql) (in query: select in(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5594: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a98c7 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:20.774444 [ 48624 ] {ff0bc84d-f974-4ca4-b0c5-3b5b4399e061} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5594: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a98c7 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:20.775922 [ 48624 ] {824bafb6-3028-4bbb-832a-87369348f6f8} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:40776) (comment: 01397_in_bad_arguments.sql) (in query: select in();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5594: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a98c7 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:20.776082 [ 48624 ] {824bafb6-3028-4bbb-832a-87369348f6f8} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5594: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a98c7 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:20.777834 [ 48624 ] {c8166e03-fcb6-4881-8a81-c1bb84f1157a} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:40776) (comment: 01397_in_bad_arguments.sql) (in query: select in(1, 2, 3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5594: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a98c7 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:20.778010 [ 48624 ] {c8166e03-fcb6-4881-8a81-c1bb84f1157a} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:5594: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a98c7 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:21.420947 [ 64953 ] {43ad6142-3dc4-44e0-b0cf-0312a4f3e20a} executeQuery: Code: 36. DB::Exception: Codec Delta is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40934) (comment: 01380_coded_delta_exception_code.sql) (in query: CREATE TABLE delta_codec_synthetic (`id` Decimal(38, 10) CODEC(Delta, ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 13273, min_bytes_for_wide_part = 481482220, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 168131559, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 24774930, merge_max_block_size = 24201, old_parts_lifetime = 30., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7222293, concurrent_part_removal_threshold = 50, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 66949, primary_key_compress_block_size = 76076), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Compression/CompressionCodecDelta.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000002f39e848 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:21.421194 [ 64953 ] {43ad6142-3dc4-44e0-b0cf-0312a4f3e20a} TCPHandler: Code: 36. DB::Exception: Codec Delta is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Compression/CompressionCodecDelta.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000002f39e848 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:21.447059 [ 64953 ] {a6fdd284-6d4e-4df9-a826-72dbf31ca03c} executeQuery: Code: 36. DB::Exception: Codec DoubleDelta is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40934) (comment: 01380_coded_delta_exception_code.sql) (in query: CREATE TABLE delta_codec_synthetic (`id` Decimal(38, 10) CODEC(DoubleDelta, ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 13273, min_bytes_for_wide_part = 481482220, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 168131559, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 24774930, merge_max_block_size = 24201, old_parts_lifetime = 30., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7222293, concurrent_part_removal_threshold = 50, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 66949, primary_key_compress_block_size = 76076), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Compression/CompressionCodecDoubleDelta.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000002f3b7908 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:21.447314 [ 64953 ] {a6fdd284-6d4e-4df9-a826-72dbf31ca03c} TCPHandler: Code: 36. DB::Exception: Codec DoubleDelta is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Compression/CompressionCodecDoubleDelta.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000002f3b7908 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:21.470425 [ 64953 ] {097b18c8-590d-4898-900d-286822df0996} executeQuery: Code: 36. DB::Exception: Codec Gorilla is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:40934) (comment: 01380_coded_delta_exception_code.sql) (in query: CREATE TABLE delta_codec_synthetic (`id` Decimal(38, 10) CODEC(Gorilla, ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 13273, min_bytes_for_wide_part = 481482220, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 168131559, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 24774930, merge_max_block_size = 24201, old_parts_lifetime = 30., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7222293, concurrent_part_removal_threshold = 50, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 66949, primary_key_compress_block_size = 76076), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Compression/CompressionCodecGorilla.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000002f3be3a8 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:21.470664 [ 64953 ] {097b18c8-590d-4898-900d-286822df0996} TCPHandler: Code: 36. DB::Exception: Codec Gorilla is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Compression/CompressionCodecGorilla.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000002f3be3a8 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:21.492694 [ 64953 ] {d79ad8a4-3370-40be-88f6-64b9b81dad30} executeQuery: Code: 433. DB::Exception: Argument value for DoubleDelta codec can be 1, 2, 4 or 8, given 3. (ILLEGAL_CODEC_PARAMETER) (version 24.3.12.76.altinitystable) (from [::1]:40934) (comment: 01380_coded_delta_exception_code.sql) (in query: CREATE TABLE delta_codec_synthetic (`id` UInt64 CODEC(DoubleDelta(3), ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 13273, min_bytes_for_wide_part = 481482220, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 168131559, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 24774930, merge_max_block_size = 24201, old_parts_lifetime = 30., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7222293, concurrent_part_removal_threshold = 50, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 66949, primary_key_compress_block_size = 76076), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000001904abbb 4. ./build_docker/./src/Compression/CompressionCodecDoubleDelta.cpp:566: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000002f3b7c2f 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:21.492936 [ 64953 ] {d79ad8a4-3370-40be-88f6-64b9b81dad30} TCPHandler: Code: 433. DB::Exception: Argument value for DoubleDelta codec can be 1, 2, 4 or 8, given 3. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000001904abbb 4. ./build_docker/./src/Compression/CompressionCodecDoubleDelta.cpp:566: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000002f3b7c2f 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:21.513718 [ 64953 ] {cdd0fbff-88be-43be-8343-8413000c634f} executeQuery: Code: 433. DB::Exception: Gorilla codec argument must be unsigned integer. (ILLEGAL_CODEC_PARAMETER) (version 24.3.12.76.altinitystable) (from [::1]:40934) (comment: 01380_coded_delta_exception_code.sql) (in query: CREATE TABLE delta_codec_synthetic (`id` UInt64 CODEC(Gorilla('hello, world'), ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 13273, min_bytes_for_wide_part = 481482220, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 168131559, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 24774930, merge_max_block_size = 24201, old_parts_lifetime = 30., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7222293, concurrent_part_removal_threshold = 50, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 66949, primary_key_compress_block_size = 76076), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Compression/CompressionCodecGorilla.cpp:468: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000002f3be5ec 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:21.514018 [ 64953 ] {cdd0fbff-88be-43be-8343-8413000c634f} TCPHandler: Code: 433. DB::Exception: Gorilla codec argument must be unsigned integer. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Compression/CompressionCodecGorilla.cpp:468: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000002f3be5ec 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:22.026061 [ 48603 ] {ace73e27-2c88-4e36-8bb2-74f16ab7b344} executeQuery: Code: 36. DB::Exception: Dictionary (`default.countryId`) not found. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:41028) (comment: 01375_GROUP_BY_injective_elimination_dictGet_BAD_ARGUMENTS.sql) (in query: SELECT dictGetString(concat('default', '.countryId'), 'country', toUInt64(number)) AS country FROM numbers(2) GROUP BY country;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:0: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000030395792 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x000000003039522a 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000018813b2d 7. DB::FunctionDictHelper::isDictGetFunctionInjective(DB::Block const&) @ 0x0000000018817642 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::isInjective(std::vector> const&) const @ 0x0000000018812142 9. ./contrib/llvm-project/libcxx/include/vector:580: DB::(anonymous namespace)::OptimizeGroupByInjectiveFunctionsVisitor::optimizeGroupingSet(std::vector, std::allocator>>&) @ 0x00000000309cd89a 10. ./build_docker/./src/Analyzer/Passes/OptimizeGroupByInjectiveFunctionsPass.cpp:0: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x00000000309ccc65 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::OptimizeGroupByInjectiveFunctionsPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000309cbc49 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:22.026384 [ 48603 ] {ace73e27-2c88-4e36-8bb2-74f16ab7b344} TCPHandler: Code: 36. DB::Exception: Dictionary (`default.countryId`) not found. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:0: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000030395792 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x000000003039522a 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000018813b2d 7. DB::FunctionDictHelper::isDictGetFunctionInjective(DB::Block const&) @ 0x0000000018817642 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::isInjective(std::vector> const&) const @ 0x0000000018812142 9. ./contrib/llvm-project/libcxx/include/vector:580: DB::(anonymous namespace)::OptimizeGroupByInjectiveFunctionsVisitor::optimizeGroupingSet(std::vector, std::allocator>>&) @ 0x00000000309cd89a 10. ./build_docker/./src/Analyzer/Passes/OptimizeGroupByInjectiveFunctionsPass.cpp:0: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x00000000309ccc65 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::OptimizeGroupByInjectiveFunctionsPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000309cbc49 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:22.930415 [ 23597 ] {ad9ac73d-f57c-4fad-b405-f16854b03994} executeQuery: Code: 36. DB::Exception: Columns: a listed both in columns to sum and in partition key. That is not allowed. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:41156) (comment: 01373_summing_merge_tree_explicit_columns_definition.sql) (in query: CREATE TABLE tt_error_1373 (`a` Int64, `d` Int64, `val` Int64) ENGINE = SummingMergeTree((a, val)) PARTITION BY a ORDER BY d SETTINGS index_granularity = 34189, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 13, min_bytes_for_full_part_storage = 94382745, compact_parts_max_bytes_to_buffer = 79546289, compact_parts_max_granules_to_buffer = 116, compact_parts_merge_max_bytes_to_prefetch_part = 13090628, merge_max_block_size = 3753, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 20975329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 90651, primary_key_compress_block_size = 36441), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000032ae8b03 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a99 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 8. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 10. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:22.930701 [ 23597 ] {ad9ac73d-f57c-4fad-b405-f16854b03994} TCPHandler: Code: 36. DB::Exception: Columns: a listed both in columns to sum and in partition key. That is not allowed. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000032ae8b03 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000032ae5a99 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:104: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000033077466 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::StorageMergeTree*>(DB::StorageMergeTree*, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000033076d6f 8. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000330766e2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003307640f 10. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:741: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d7e6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:22.992716 [ 23597 ] {4b72e97e-3bd2-4577-9d8a-e848225f1d1a} executeQuery: Code: 62. DB::Exception: Invalid qualified name: a. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:41178) (comment: 01372_remote_table_function_empty_table.sql) (in query: SELECT * FROM remote('127..2', 'a.');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::QualifiedTableName::parseFromString(String const&) @ 0x000000001809216b 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4316ca 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:22.993013 [ 23597 ] {4b72e97e-3bd2-4577-9d8a-e848225f1d1a} TCPHandler: Code: 62. DB::Exception: Invalid qualified name: a. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::QualifiedTableName::parseFromString(String const&) @ 0x000000001809216b 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e4316ca 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:23.823088 [ 23597 ] {4dd6f53e-b060-47dd-92d4-3e94eb2de0af} executeQuery: Code: 59. DB::Exception: Invalid type for filter in PREWHERE: String. In query SELECT t0.c2, t0.c1, t0.c0 FROM t0 PREWHERE t0.c0 ORDER BY t0.c2 >= t0.c1 ASC, (-(t0.c0 > t0.c0)) IS NULL ASC. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.3.12.76.altinitystable) (from [::1]:41300) (comment: 01356_wrong_filter-type_bug.sql) (in query: SELECT t0.c2, t0.c1, t0.c0 FROM t0 PREWHERE t0.c0 ORDER BY ((t0.c2)>=(t0.c1)), (((- (((t0.c0)>(t0.c0))))) IS NULL) FORMAT TabSeparatedWithNamesAndTypes;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002f119af1 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003093a14b 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:47: DB::validateFilters(std::shared_ptr const&) @ 0x0000000030939ae9 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875940 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:23.823223 [ 23597 ] {4dd6f53e-b060-47dd-92d4-3e94eb2de0af} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in PREWHERE: String. In query SELECT t0.c2, t0.c1, t0.c0 FROM t0 PREWHERE t0.c0 ORDER BY t0.c2 >= t0.c1 ASC, (-(t0.c0 > t0.c0)) IS NULL ASC. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002f119af1 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003093a14b 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:47: DB::validateFilters(std::shared_ptr const&) @ 0x0000000030939ae9 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875940 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:23.825510 [ 23597 ] {c32d2297-3428-48ae-9ada-08622d62c056} executeQuery: Code: 59. DB::Exception: Invalid type for filter in WHERE: String. In query SELECT t0.c2, t0.c1, t0.c0 FROM t0 WHERE t0.c0 ORDER BY t0.c2 >= t0.c1 ASC, (-(t0.c0 > t0.c0)) IS NULL ASC. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.3.12.76.altinitystable) (from [::1]:41300) (comment: 01356_wrong_filter-type_bug.sql) (in query: SELECT t0.c2, t0.c1, t0.c0 FROM t0 WHERE t0.c0 ORDER BY ((t0.c2)>=(t0.c1)), (((- (((t0.c0)>(t0.c0))))) IS NULL) FORMAT TabSeparatedWithNamesAndTypes settings optimize_move_to_prewhere=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002f119af1 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003093a14b 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:57: DB::validateFilters(std::shared_ptr const&) @ 0x0000000030939c1e 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875940 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:23.825650 [ 23597 ] {c32d2297-3428-48ae-9ada-08622d62c056} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in WHERE: String. In query SELECT t0.c2, t0.c1, t0.c0 FROM t0 WHERE t0.c0 ORDER BY t0.c2 >= t0.c1 ASC, (-(t0.c0 > t0.c0)) IS NULL ASC. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002f119af1 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003093a14b 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:57: DB::validateFilters(std::shared_ptr const&) @ 0x0000000030939c1e 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x0000000030875940 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.364228 [ 23597 ] {874b193a-04e5-4051-9339-3f3edfe3e244} executeQuery: Code: 153. DB::Exception: Division of minimal signed number by minus one: In scope SELECT intDiv(-9223372036854775808, 18446744073709551615). (ILLEGAL_DIVISION) (version 24.3.12.76.altinitystable) (from [::1]:41372) (comment: 01350_intdiv_nontrivial_fpe.sql) (in query: select intDiv(-9223372036854775808, 18446744073709551615);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000001aad2c34 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d328542 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001d327f42 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d32415f 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d25212c 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d24d3ac 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d24a585 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d2484b1 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:15:24.364450 [ 23597 ] {874b193a-04e5-4051-9339-3f3edfe3e244} TCPHandler: Code: 153. DB::Exception: Division of minimal signed number by minus one: In scope SELECT intDiv(-9223372036854775808, 18446744073709551615). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000001aad2c34 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d328542 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001d327f42 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d32415f 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d25212c 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d24d3ac 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d24a585 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d2484b1 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:15:24.397010 [ 23597 ] {ff3658f6-15e3-461d-9dd1-941aa1332fd9} executeQuery: Code: 153. DB::Exception: Division of minimal signed number by minus one: In scope SELECT intDiv(-9223372036854775808, -1). (ILLEGAL_DIVISION) (version 24.3.12.76.altinitystable) (from [::1]:41372) (comment: 01350_intdiv_nontrivial_fpe.sql) (in query: select intDiv(-9223372036854775808, -1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000001aad2c34 5. COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber<_BitInt(8)>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d32b655 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber<_BitInt(8)>>(auto const&, auto const&) const @ 0x000000001d32b022 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d3242df 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d25212c 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d24d3ac 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d24a585 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d2484b1 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:15:24.397219 [ 23597 ] {ff3658f6-15e3-461d-9dd1-941aa1332fd9} TCPHandler: Code: 153. DB::Exception: Division of minimal signed number by minus one: In scope SELECT intDiv(-9223372036854775808, -1). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000001aad2c34 5. COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber<_BitInt(8)>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d32b655 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber<_BitInt(8)>>(auto const&, auto const&) const @ 0x000000001d32b022 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d3242df 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d25212c 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d24d3ac 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d24a585 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d2484b1 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:15:24.712054 [ 23606 ] {0a6602be-a914-4d51-af47-6498c94a074e} executeQuery: Code: 519. DB::NetException: All attempts to get table structure failed. Log: Code: 279. DB::NetException: All connection tries failed. Log: Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) . (ALL_CONNECTION_TRIES_FAILED) (version 24.3.12.76.altinitystable) . (NO_REMOTE_SHARD_AVAILABLE) (version 24.3.12.76.altinitystable) (from [::1]:41462) (comment: 01361_fover_remote_num_tries.sh) (in query: SELECT hostName() FROM remote('128.1.2.3', default.tmp)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000326ba9ec 4. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:169: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x00000000326b7db8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e43605a 6. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e434db0 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 8. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.727771 [ 48598 ] {cd8caf05-d2f7-4f7f-9b70-814609070187} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Enum8('hello' = 1, 'world' = 2, 'goodbye' = 3) to type Enum8('hello' = 1, 'world' = 2) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:41432) (comment: 01344_alter_enum_partition_key.sql) (in query: ALTER TABLE test MODIFY COLUMN x Enum('hello' = 1, 'world' = 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44447 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.727843 [ 23606 ] {0a6602be-a914-4d51-af47-6498c94a074e} TCPHandler: Code: 519. DB::NetException: All attempts to get table structure failed. Log: Code: 279. DB::NetException: All connection tries failed. Log: Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) . (ALL_CONNECTION_TRIES_FAILED) (version 24.3.12.76.altinitystable) . (NO_REMOTE_SHARD_AVAILABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000326ba9ec 4. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:169: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x00000000326b7db8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e43605a 6. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:0: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e434db0 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 8. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.728050 [ 48598 ] {cd8caf05-d2f7-4f7f-9b70-814609070187} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Enum8('hello' = 1, 'world' = 2, 'goodbye' = 3) to type Enum8('hello' = 1, 'world' = 2) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44447 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.740395 [ 48598 ] {51cb5e87-f782-4111-ac42-f62d5323270b} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Enum8('hello' = 1, 'world' = 2, 'test' = 3) to type Enum8('hello' = 1, 'world' = 2, 'goodbye' = 4) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:41432) (comment: 01344_alter_enum_partition_key.sql) (in query: ALTER TABLE test MODIFY COLUMN x Enum('hello' = 1, 'world' = 2, 'goodbye' = 4);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44447 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.740542 [ 48598 ] {51cb5e87-f782-4111-ac42-f62d5323270b} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Enum8('hello' = 1, 'world' = 2, 'test' = 3) to type Enum8('hello' = 1, 'world' = 2, 'goodbye' = 4) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44447 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.775690 [ 48598 ] {b602e8bf-2cb8-412b-9381-3277f69db52f} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Enum8('' = 1) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:41432) (comment: 01344_alter_enum_partition_key.sql) (in query: ALTER TABLE test MODIFY COLUMN x Enum8('' = 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44447 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.775803 [ 48598 ] {b602e8bf-2cb8-412b-9381-3277f69db52f} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Enum8('' = 1) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44447 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.777865 [ 48598 ] {a049141d-c800-47d3-87ad-d414b920546f} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Enum16('' = 1) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:41432) (comment: 01344_alter_enum_partition_key.sql) (in query: ALTER TABLE test MODIFY COLUMN x Enum16('' = 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44447 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.777966 [ 48598 ] {a049141d-c800-47d3-87ad-d414b920546f} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Enum16('' = 1) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44447 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.779996 [ 48598 ] {dc3c1562-b2c5-4a15-9d5f-fcf37c1ef277} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type UInt64 is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:41432) (comment: 01344_alter_enum_partition_key.sql) (in query: ALTER TABLE test MODIFY COLUMN x UInt64;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44447 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.780101 [ 48598 ] {dc3c1562-b2c5-4a15-9d5f-fcf37c1ef277} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type UInt64 is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44447 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.782145 [ 48598 ] {825e6509-4cc9-4e6f-bf7e-f803ee41ef1f} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type String is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:41432) (comment: 01344_alter_enum_partition_key.sql) (in query: ALTER TABLE test MODIFY COLUMN x String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44447 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.782236 [ 48598 ] {825e6509-4cc9-4e6f-bf7e-f803ee41ef1f} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type String is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44447 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.784229 [ 48598 ] {fb31d205-2be6-418b-baf7-0229017dbea5} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Nullable(Int64) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:41432) (comment: 01344_alter_enum_partition_key.sql) (in query: ALTER TABLE test MODIFY COLUMN x Nullable(Int64);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44447 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.784319 [ 48598 ] {fb31d205-2be6-418b-baf7-0229017dbea5} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Nullable(Int64) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b44447 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.801138 [ 48598 ] {a82e9fa5-00c3-4782-8bfd-2c7fa98542c4} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key x column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:41432) (comment: 01344_alter_enum_partition_key.sql) (in query: ALTER TABLE test RENAME COLUMN x TO z;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4348e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.801288 [ 48598 ] {a82e9fa5-00c3-4782-8bfd-2c7fa98542c4} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key x column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4348e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.803035 [ 48598 ] {8f46bfab-59a8-4c9a-8748-2556053467ab} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key y column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:41432) (comment: 01344_alter_enum_partition_key.sql) (in query: ALTER TABLE test RENAME COLUMN y TO z;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4348e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.803139 [ 48598 ] {8f46bfab-59a8-4c9a-8748-2556053467ab} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key y column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4348e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.822025 [ 48598 ] {c08dd29a-8ce3-48e4-849f-596c5cb5eb69} executeQuery: Code: 47. DB::Exception: Missing columns: 'x' while processing query: 'x', required columns: 'x' 'x'. (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:41432) (comment: 01344_alter_enum_partition_key.sql) (in query: ALTER TABLE test DROP COLUMN x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x00000000315b73f2 5. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1509: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000315c774b 6. ./build_docker/./src/Storages/KeyDescription.cpp:140: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000320fa1e8 7. ./build_docker/./src/Storages/KeyDescription.cpp:0: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x00000000320f9bde 8. ./build_docker/./src/Storages/AlterCommands.cpp:1145: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000032083f43 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3e11f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.822203 [ 48598 ] {c08dd29a-8ce3-48e4-849f-596c5cb5eb69} TCPHandler: Code: 47. DB::Exception: Missing columns: 'x' while processing query: 'x', required columns: 'x' 'x'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x00000000315b73f2 5. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1509: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000315c774b 6. ./build_docker/./src/Storages/KeyDescription.cpp:140: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000320fa1e8 7. ./build_docker/./src/Storages/KeyDescription.cpp:0: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x00000000320f9bde 8. ./build_docker/./src/Storages/AlterCommands.cpp:1145: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000032083f43 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3e11f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.842697 [ 48598 ] {0b78b542-9109-4e65-94f0-e714579d54dc} executeQuery: Code: 47. DB::Exception: Missing columns: 'y' while processing query: 'y', required columns: 'y' 'y'. (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:41432) (comment: 01344_alter_enum_partition_key.sql) (in query: ALTER TABLE test DROP COLUMN y;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x00000000315b73f2 5. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1509: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000315c774b 6. ./build_docker/./src/Storages/KeyDescription.cpp:140: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000320fa1e8 7. ./build_docker/./src/Storages/KeyDescription.cpp:0: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x00000000320f9bde 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000032083cd2 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3e11f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.842885 [ 48598 ] {0b78b542-9109-4e65-94f0-e714579d54dc} TCPHandler: Code: 47. DB::Exception: Missing columns: 'y' while processing query: 'y', required columns: 'y' 'y'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x00000000315b73f2 5. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1509: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000315c774b 6. ./build_docker/./src/Storages/KeyDescription.cpp:140: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000320fa1e8 7. ./build_docker/./src/Storages/KeyDescription.cpp:0: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x00000000320f9bde 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000032083cd2 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b3e11f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:24.980375 [ 23606 ] {a85b175a-66db-42e5-8003-807c17fd31f7} executeQuery: Code: 6. DB::Exception: Cannot parse string '2019-09-16 19:20:12.3456789102019-09-16 19:20:12.345678910' as DateTime64(0): syntax error at position 33 (parsed just '2019-09-16 19:20:12.3456789102019'): In scope WITH toDateTime64('2019-09-16 19:20:12.3456789102019-09-16 19:20:12.345678910', 0) AS dt64 SELECT dt64. (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: WITH toDateTime64('2019-09-16 19:20:12.3456789102019-09-16 19:20:12.345678910', 0) AS dt64 SELECT dt64;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 22. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 28. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 30. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 2025.03.05 21:15:24.980637 [ 23606 ] {a85b175a-66db-42e5-8003-807c17fd31f7} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2019-09-16 19:20:12.3456789102019-09-16 19:20:12.345678910' as DateTime64(0): syntax error at position 33 (parsed just '2019-09-16 19:20:12.3456789102019'): In scope WITH toDateTime64('2019-09-16 19:20:12.3456789102019-09-16 19:20:12.345678910', 0) AS dt64 SELECT dt64. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 22. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 28. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 30. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 2025.03.05 21:15:25.044377 [ 23606 ] {eeb4c5c2-8610-47f3-a16c-6f711138f663} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-12345678901234567890' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-12345678901234567890', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-12345678901234567890', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.044626 [ 23606 ] {eeb4c5c2-8610-47f3-a16c-6f711138f663} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-12345678901234567890' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-12345678901234567890', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.102190 [ 23606 ] {85a13af5-184e-4d71-8a6a-5e50c2a13ec5} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-1', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.102344 [ 23606 ] {85a13af5-184e-4d71-8a6a-5e50c2a13ec5} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.103657 [ 23606 ] {86a2405f-5b77-4f42-a61a-1f692109ed8e} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-11', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.103806 [ 23606 ] {86a2405f-5b77-4f42-a61a-1f692109ed8e} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.105100 [ 23606 ] {5a2486a7-3497-4019-a6f1-b2206da1298a} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.105220 [ 23606 ] {5a2486a7-3497-4019-a6f1-b2206da1298a} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.106461 [ 23606 ] {d0f0da1d-c575-4c27-84c6-47a99be6cddc} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-1111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.106571 [ 23606 ] {d0f0da1d-c575-4c27-84c6-47a99be6cddc} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.107885 [ 23606 ] {08cdf48e-a807-43d6-ac9d-b8fd6cf5209c} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-11111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.108002 [ 23606 ] {08cdf48e-a807-43d6-ac9d-b8fd6cf5209c} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.109336 [ 23606 ] {e3fad1d0-e96e-431b-8a1b-fa7dabfc03bf} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.109449 [ 23606 ] {e3fad1d0-e96e-431b-8a1b-fa7dabfc03bf} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.111555 [ 23606 ] {ee8d2555-10bf-4858-900c-a417352332a3} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-1111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.111787 [ 23606 ] {ee8d2555-10bf-4858-900c-a417352332a3} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.113500 [ 23606 ] {6ee2601e-519f-455c-be27-c23ea5e94f87} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-11111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.113658 [ 23606 ] {6ee2601e-519f-455c-be27-c23ea5e94f87} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.115451 [ 23606 ] {0d80ffed-cddf-45ba-bb97-1d781378b273} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.115602 [ 23606 ] {0d80ffed-cddf-45ba-bb97-1d781378b273} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.117656 [ 23606 ] {995289d0-58ca-484d-99ce-67cbab4585d9} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111111', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-1111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.117839 [ 23606 ] {995289d0-58ca-484d-99ce-67cbab4585d9} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.119708 [ 23606 ] {fbd61bb8-807b-4e14-a96f-cb43f6053e08} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111111', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-11111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.119870 [ 23606 ] {fbd61bb8-807b-4e14-a96f-cb43f6053e08} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.121757 [ 23606 ] {9b48adf5-0733-4b60-a454-9db302558638} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111111', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.121961 [ 23606 ] {9b48adf5-0733-4b60-a454-9db302558638} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.123904 [ 23606 ] {4e647ee7-1c68-433a-b8bd-ec0c3295f804} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111111111', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-1111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.124063 [ 23606 ] {4e647ee7-1c68-433a-b8bd-ec0c3295f804} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.127065 [ 23606 ] {94d17d1a-23d8-4961-894f-f3d130e06d45} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111111111', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-11111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.127246 [ 23606 ] {94d17d1a-23d8-4961-894f-f3d130e06d45} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.129005 [ 23606 ] {f77e1518-ab95-4a8b-8086-6d2a5c65d64d} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111111111', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-111111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.129217 [ 23606 ] {f77e1518-ab95-4a8b-8086-6d2a5c65d64d} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.130919 [ 23606 ] {e4a02b5f-9d98-40a7-bb1a-57ed4e1dfb33} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111111111111', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-1111111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.131070 [ 23606 ] {e4a02b5f-9d98-40a7-bb1a-57ed4e1dfb33} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.132599 [ 23606 ] {65ab4da9-f093-441e-b4e9-eb221d2d279a} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111111111111', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-11111111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.132821 [ 23606 ] {65ab4da9-f093-441e-b4e9-eb221d2d279a} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.134358 [ 23606 ] {9127fcfb-e356-4340-bcc6-2220439eb4b4} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111111111111', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-111111111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.134504 [ 23606 ] {9127fcfb-e356-4340-bcc6-2220439eb4b4} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.136234 [ 23606 ] {f57766e0-dedf-4229-8a68-5df3d9399a8f} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111111111111111', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-1111111111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.136380 [ 23606 ] {f57766e0-dedf-4229-8a68-5df3d9399a8f} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.137998 [ 23606 ] {79603fb7-335a-4662-8385-e537d848195a} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111111111111111', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-11111111111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.138155 [ 23606 ] {79603fb7-335a-4662-8385-e537d848195a} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.139657 [ 23606 ] {d52e565c-95a1-4e43-b4bf-e267958c15a0} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111111111111111', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-111111111111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.139816 [ 23606 ] {d52e565c-95a1-4e43-b4bf-e267958c15a0} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.141364 [ 23606 ] {d508364d-a1eb-488c-8d55-c5ce2847f031} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+1' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+1', 0). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+1', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.141505 [ 23606 ] {d508364d-a1eb-488c-8d55-c5ce2847f031} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+1' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+1', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.175179 [ 23606 ] {bf3a1e80-5761-42fa-929e-b929c4fafa5f} executeQuery: Code: 69. DB::Exception: Scale 10 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.++11', 10). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.++11', 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.175412 [ 23606 ] {bf3a1e80-5761-42fa-929e-b929c4fafa5f} TCPHandler: Code: 69. DB::Exception: Scale 10 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.++11', 10). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.177699 [ 23606 ] {5f064962-bb4c-4cf7-82e7-8b944156f18a} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+111' as DateTime64(3): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+111', 3). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+111', 3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.177823 [ 23606 ] {5f064962-bb4c-4cf7-82e7-8b944156f18a} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+111' as DateTime64(3): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+111', 3). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.179353 [ 23606 ] {9b3bb914-9ef1-4ce9-9de1-7e33b309dc7f} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+++1111' as DateTime64(5): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+++1111', 5). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+++1111', 5);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.179461 [ 23606 ] {9b3bb914-9ef1-4ce9-9de1-7e33b309dc7f} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+++1111' as DateTime64(5): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+++1111', 5). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.181055 [ 23606 ] {ae35011d-ae4e-4c83-8460-c4146425ec58} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+11111' as DateTime64(7): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+11111', 7). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+11111', 7);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.181157 [ 23606 ] {ae35011d-ae4e-4c83-8460-c4146425ec58} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+11111' as DateTime64(7): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+11111', 7). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.182556 [ 23606 ] {52fdb117-9a4c-456c-8c66-eeca2243fb05} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+++++111111' as DateTime64(2): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+++++111111', 2). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+++++111111', 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.182679 [ 23606 ] {52fdb117-9a4c-456c-8c66-eeca2243fb05} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+++++111111' as DateTime64(2): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+++++111111', 2). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.184264 [ 23606 ] {6ca95d25-8fa0-4d43-b6a4-eb51c88cc0cc} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+1111111' as DateTime64(1): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+1111111', 1). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+1111111', 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.184369 [ 23606 ] {6ca95d25-8fa0-4d43-b6a4-eb51c88cc0cc} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+1111111' as DateTime64(1): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+1111111', 1). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.185959 [ 23606 ] {8ade138b-e3f7-4325-a8ff-9ede0568a8ec} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.++++++11111111' as DateTime64(8): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.++++++11111111', 8). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.++++++11111111', 8);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.186073 [ 23606 ] {8ade138b-e3f7-4325-a8ff-9ede0568a8ec} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.++++++11111111' as DateTime64(8): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.++++++11111111', 8). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.187431 [ 23606 ] {51dff0fe-9356-490f-b3fa-50310f4af8d3} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+111111111' as DateTime64(9): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+111111111', 9). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+111111111', 9);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.187538 [ 23606 ] {51dff0fe-9356-490f-b3fa-50310f4af8d3} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+111111111' as DateTime64(9): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+111111111', 9). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.189086 [ 23606 ] {e5110f19-00a6-4ad4-8946-b36003cfb932} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+++++++1111111111' as DateTime64(6): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+++++++1111111111', 6). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+++++++1111111111', 6);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.189191 [ 23606 ] {e5110f19-00a6-4ad4-8946-b36003cfb932} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+++++++1111111111' as DateTime64(6): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+++++++1111111111', 6). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.190583 [ 23606 ] {3df888c7-5d2a-4a87-9121-13e2331203dc} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+11111111111' as DateTime64(4): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+11111111111', 4). (CANNOT_PARSE_TEXT) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+11111111111', 4);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.190707 [ 23606 ] {3df888c7-5d2a-4a87-9121-13e2331203dc} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+11111111111' as DateTime64(4): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+11111111111', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000018280821 5. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000001867fb55 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018676ea5 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018669a8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 12. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.192039 [ 23606 ] {b9871559-e698-453d-9596-d67227ea3d15} executeQuery: Code: 69. DB::Exception: Scale 11 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.++++++++111111111111', 11). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.++++++++111111111111', 11);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.192136 [ 23606 ] {b9871559-e698-453d-9596-d67227ea3d15} TCPHandler: Code: 69. DB::Exception: Scale 11 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.++++++++111111111111', 11). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.194236 [ 23606 ] {56acc27e-9cbb-463c-b08a-3875a77c6c36} executeQuery: Code: 69. DB::Exception: Scale 15 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+1111111111111', 15). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+1111111111111', 15);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.194406 [ 23606 ] {56acc27e-9cbb-463c-b08a-3875a77c6c36} TCPHandler: Code: 69. DB::Exception: Scale 15 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+1111111111111', 15). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.196053 [ 23606 ] {6d7f9046-8727-47f0-9f56-2292ebbbc9b3} executeQuery: Code: 69. DB::Exception: Scale 13 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+++++++++11111111111111', 13). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+++++++++11111111111111', 13);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.196189 [ 23606 ] {6d7f9046-8727-47f0-9f56-2292ebbbc9b3} TCPHandler: Code: 69. DB::Exception: Scale 13 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+++++++++11111111111111', 13). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.197815 [ 23606 ] {cbc3c40a-6236-40b0-a549-3f1c4db422b8} executeQuery: Code: 69. DB::Exception: Scale 12 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+111111111111111', 12). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+111111111111111', 12);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.197948 [ 23606 ] {cbc3c40a-6236-40b0-a549-3f1c4db422b8} TCPHandler: Code: 69. DB::Exception: Scale 12 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+111111111111111', 12). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.199636 [ 23606 ] {a5c2d36c-538e-49ce-b9bb-d4bfe691470a} executeQuery: Code: 69. DB::Exception: Scale 16 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.++++++++++1111111111111111', 16). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.++++++++++1111111111111111', 16);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.199812 [ 23606 ] {a5c2d36c-538e-49ce-b9bb-d4bfe691470a} TCPHandler: Code: 69. DB::Exception: Scale 16 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.++++++++++1111111111111111', 16). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.201551 [ 23606 ] {bd41a298-bac8-4a77-ba03-6fa10fcfd47b} executeQuery: Code: 69. DB::Exception: Scale 14 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+11111111111111111', 14). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+11111111111111111', 14);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.201761 [ 23606 ] {bd41a298-bac8-4a77-ba03-6fa10fcfd47b} TCPHandler: Code: 69. DB::Exception: Scale 14 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+11111111111111111', 14). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.203860 [ 23606 ] {841cb6b3-62bf-48b3-a85a-76642f62a8fe} executeQuery: Code: 69. DB::Exception: Scale 15 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+++++++++++111111111111111111', 15). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+++++++++++111111111111111111', 15);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.204049 [ 23606 ] {841cb6b3-62bf-48b3-a85a-76642f62a8fe} TCPHandler: Code: 69. DB::Exception: Scale 15 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+++++++++++111111111111111111', 15). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.205870 [ 23606 ] {6f7276d8-3dd5-4fcc-bc82-416ea8c2cfe4} executeQuery: Code: 69. DB::Exception: Scale 17 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+1111111111111111111', 17). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+1111111111111111111', 17);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.205997 [ 23606 ] {6f7276d8-3dd5-4fcc-bc82-416ea8c2cfe4} TCPHandler: Code: 69. DB::Exception: Scale 17 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+1111111111111111111', 17). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.241703 [ 23606 ] {7ff38c71-8208-43c1-bc62-0a8b9cc40508} executeQuery: Code: 69. DB::Exception: Scale 19 is out of bounds (max scale: 18): In scope SELECT toDateTime64('2011-11-11 11:11:11.++++++++++++11111111111111111111', 19). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.++++++++++++11111111111111111111', 19);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000001806a053 4. ./src/DataTypes/DataTypeDecimalBase.h:0: DB::DataTypeDecimalBase::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002f46a2de 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:23: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f464f6f 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 7. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 8. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 9. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 10. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 11. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 12. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:25.241911 [ 23606 ] {7ff38c71-8208-43c1-bc62-0a8b9cc40508} TCPHandler: Code: 69. DB::Exception: Scale 19 is out of bounds (max scale: 18): In scope SELECT toDateTime64('2011-11-11 11:11:11.++++++++++++11111111111111111111', 19). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000001806a053 4. ./src/DataTypes/DataTypeDecimalBase.h:0: DB::DataTypeDecimalBase::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002f46a2de 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:23: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f464f6f 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 7. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 8. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 9. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 10. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 11. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 12. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:25.243994 [ 23606 ] {270ce0b0-af7e-4b12-9a95-f70c1a142e96} executeQuery: Code: 69. DB::Exception: Scale 18 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+111111111111111111111', 18). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:41514) (comment: 01340_datetime64_fpe.sql) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+111111111111111111111', 18);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.244102 [ 23606 ] {270ce0b0-af7e-4b12-9a95-f70c1a142e96} TCPHandler: Code: 69. DB::Exception: Scale 18 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+111111111111111111111', 18). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002f4650ce 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned int&, String&&) @ 0x000000001878cf81 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned int&, String, void>(std::allocator const&, unsigned int&, String&&) @ 0x000000001878ccc6 7. std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x0000000018684a7d 8. DB::(anonymous namespace)::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000001866b3ef 9. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 10. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 11. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:25.332847 [ 23606 ] {935d109d-bb78-4cee-ba2b-71e3f448404e} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '(' at end of stream.: while converting '' to Tuple(UInt8): In scope SELECT tuple(1) < ''. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.3.12.76.altinitystable) (from [::1]:41604) (comment: 01329_compare_tuple_string_constant.sql) (in query: SELECT tuple(1) < '';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./src/IO/ReadHelpers.h:203: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000002f6a70ce 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031699857 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 8. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dd6612a 9. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dd467c5 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.333093 [ 23606 ] {935d109d-bb78-4cee-ba2b-71e3f448404e} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '(' at end of stream.: while converting '' to Tuple(UInt8): In scope SELECT tuple(1) < ''. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./src/IO/ReadHelpers.h:203: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000002f6a70ce 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031699857 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 8. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dd6612a 9. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dd467c5 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 19. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:25.360508 [ 23606 ] {1341b4bf-73fa-4b0d-8090-f5d24b769e7d} executeQuery: Code: 386. DB::Exception: There is no supertype for types Tuple(UInt8), String because some of them are Tuple and some of them are not. (NO_COMMON_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:41604) (comment: 01329_compare_tuple_string_constant.sql) (in query: SELECT tuple(1) < materialize('');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58eebc 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001dd68b4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dd47611 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 17. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 18. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:25.402115 [ 23620 ] {c16490f0-b82b-49d8-8010-6fcf9747a7bf} executeQuery: Code: 62. DB::Exception: ASOF join needs at least one equi-join column. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:41590) (comment: 01332_join_type_syntax_position.sql) (in query: select * from numbers(1) t1 asof join numbers(1) t2 using number;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/HashJoin.cpp:301: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&) @ 0x00000000303e649d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::HashJoin* std::construct_at[abi:v15000]&, DB::Block const&, DB::HashJoin*>(DB::HashJoin*, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f962 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::Block const&>(std::allocator, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f381 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr&, DB::Block const&, void>(std::allocator const&, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f144 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a3e2 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:25.402135 [ 23606 ] {1341b4bf-73fa-4b0d-8090-f5d24b769e7d} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Tuple(UInt8), String because some of them are Tuple and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x00000000208ae0f3 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f5897c8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f58eebc 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001dd68b4a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dd47611 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 15. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 17. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 18. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:25.430418 [ 23635 ] {49502807-ff6a-480c-8869-8d69b7378ffd} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 15 digits were read: 123456789123451e-1. Expected to read decimal with scale 5 and precision 18: In scope SELECT CAST('12345678912345.1', 'Decimal(10, 5)'). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:41632) (comment: 01327_decimal_cut_extra_digits_after_point.sql) (in query: -- But it's just Decimal64, so there is the limit. SELECT CAST('12345678912345.1' AS Decimal(10, 5));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000002f52d065 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f5289ae 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5db7ca 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl>, DB::(anonymous namespace)::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, unsigned int) @ 0x0000000018413957 7. bool DB::callOnIndexAndDataType>, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, DB::DataTypeDecimal> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDecimal> const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, DB::DataTypeDecimal> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDecimal> const&)&&) @ 0x00000000184030ca 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, DB::DataTypeDecimal> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000183fe5c3 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:15:25.430535 [ 23620 ] {c16490f0-b82b-49d8-8010-6fcf9747a7bf} TCPHandler: Code: 62. DB::Exception: ASOF join needs at least one equi-join column. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/HashJoin.cpp:301: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&) @ 0x00000000303e649d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::HashJoin* std::construct_at[abi:v15000]&, DB::Block const&, DB::HashJoin*>(DB::HashJoin*, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f962 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::Block const&>(std::allocator, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f381 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr&, DB::Block const&, void>(std::allocator const&, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f144 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a3e2 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:25.430740 [ 23635 ] {49502807-ff6a-480c-8869-8d69b7378ffd} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 15 digits were read: 123456789123451e-1. Expected to read decimal with scale 5 and precision 18: In scope SELECT CAST('12345678912345.1', 'Decimal(10, 5)'). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x000000002f52d065 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f5289ae 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5db7ca 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertImpl>, DB::(anonymous namespace)::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::(anonymous namespace)::BehaviourOnErrorFromString, unsigned int) @ 0x0000000018413957 7. bool DB::callOnIndexAndDataType>, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, DB::DataTypeDecimal> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDecimal> const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, DB::DataTypeDecimal> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeDecimal> const&)&&) @ 0x00000000184030ca 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, DB::DataTypeDecimal> const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000183fe5c3 9. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:15:25.435436 [ 23620 ] {720cc6b7-cde0-454a-9af2-d167ccfcd669} executeQuery: Code: 62. DB::Exception: ASOF join needs at least one equi-join column. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:41590) (comment: 01332_join_type_syntax_position.sql) (in query: select * from numbers(1) t1 left asof join numbers(1) t2 using number;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/HashJoin.cpp:301: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&) @ 0x00000000303e649d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::HashJoin* std::construct_at[abi:v15000]&, DB::Block const&, DB::HashJoin*>(DB::HashJoin*, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f962 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::Block const&>(std::allocator, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f381 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr&, DB::Block const&, void>(std::allocator const&, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f144 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a3e2 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:25.435760 [ 23620 ] {720cc6b7-cde0-454a-9af2-d167ccfcd669} TCPHandler: Code: 62. DB::Exception: ASOF join needs at least one equi-join column. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/HashJoin.cpp:301: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&) @ 0x00000000303e649d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::HashJoin* std::construct_at[abi:v15000]&, DB::Block const&, DB::HashJoin*>(DB::HashJoin*, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f962 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::Block const&>(std::allocator, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f381 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr&, DB::Block const&, void>(std::allocator const&, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f144 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a3e2 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:25.474064 [ 23620 ] {907f7efa-0e3c-4d73-a37c-232ce36fc343} executeQuery: Code: 62. DB::Exception: ASOF join needs at least one equi-join column. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:41590) (comment: 01332_join_type_syntax_position.sql) (in query: select * from numbers(1) t1 asof join numbers(1) t2 using number;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/HashJoin.cpp:301: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&) @ 0x00000000303e649d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::HashJoin* std::construct_at[abi:v15000]&, DB::Block const&, DB::HashJoin*>(DB::HashJoin*, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f962 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::Block const&>(std::allocator, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f381 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr&, DB::Block const&, void>(std::allocator const&, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f144 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a3e2 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:25.474292 [ 23620 ] {907f7efa-0e3c-4d73-a37c-232ce36fc343} TCPHandler: Code: 62. DB::Exception: ASOF join needs at least one equi-join column. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/HashJoin.cpp:301: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&) @ 0x00000000303e649d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::HashJoin* std::construct_at[abi:v15000]&, DB::Block const&, DB::HashJoin*>(DB::HashJoin*, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f962 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::Block const&>(std::allocator, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f381 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr&, DB::Block const&, void>(std::allocator const&, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f144 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a3e2 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:25.477116 [ 23620 ] {36324bff-fe5e-419b-bce9-3d0704572a54} executeQuery: Code: 62. DB::Exception: ASOF join needs at least one equi-join column. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:41590) (comment: 01332_join_type_syntax_position.sql) (in query: select * from numbers(1) t1 asof left join numbers(1) t2 using number;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/HashJoin.cpp:301: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&) @ 0x00000000303e649d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::HashJoin* std::construct_at[abi:v15000]&, DB::Block const&, DB::HashJoin*>(DB::HashJoin*, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f962 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::Block const&>(std::allocator, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f381 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr&, DB::Block const&, void>(std::allocator const&, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f144 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a3e2 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:25.477280 [ 23620 ] {36324bff-fe5e-419b-bce9-3d0704572a54} TCPHandler: Code: 62. DB::Exception: ASOF join needs at least one equi-join column. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/HashJoin.cpp:301: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&) @ 0x00000000303e649d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::HashJoin* std::construct_at[abi:v15000]&, DB::Block const&, DB::HashJoin*>(DB::HashJoin*, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f962 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, DB::Block const&>(std::allocator, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f381 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr&, DB::Block const&, void>(std::allocator const&, std::shared_ptr&, DB::Block const&) @ 0x000000002fe0f144 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a3e2 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 10. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:25.759989 [ 23635 ] {007a0eba-79c7-4fc9-97e1-968370363200} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT max(multiply(1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:41702) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT max(multiply(1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:25.760213 [ 23635 ] {007a0eba-79c7-4fc9-97e1-968370363200} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT max(multiply(1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:25.762400 [ 23635 ] {6746a218-b8b3-4298-a917-4799f71ec2c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT min(multiply(2)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:41702) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT min(multiply(2));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:25.762596 [ 23635 ] {6746a218-b8b3-4298-a917-4799f71ec2c2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT min(multiply(2)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:25.764610 [ 23635 ] {6d7b34e6-33ac-40cf-8580-c71a96627c78} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT sum(multiply(3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:41702) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT sum(multiply(3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:25.764810 [ 23635 ] {6d7b34e6-33ac-40cf-8580-c71a96627c78} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT sum(multiply(3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:25.766862 [ 23635 ] {8b7b8472-adc2-42ec-b694-fb13a1ff88d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT max(plus(1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:41702) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT max(plus(1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:25.767003 [ 23635 ] {8b7b8472-adc2-42ec-b694-fb13a1ff88d9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT max(plus(1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:25.768525 [ 23635 ] {77a1bc08-6c6c-4e02-ae96-f03012c60218} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT min(plus(2)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:41702) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT min(plus(2));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:25.768630 [ 23635 ] {77a1bc08-6c6c-4e02-ae96-f03012c60218} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT min(plus(2)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:25.770153 [ 23635 ] {ab7ae7e6-78fd-4915-8da2-8bf5370b57f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT sum(plus(3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:41702) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT sum(plus(3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:25.770263 [ 23635 ] {ab7ae7e6-78fd-4915-8da2-8bf5370b57f8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT sum(plus(3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:25.771769 [ 23635 ] {a969c79c-209b-4710-b30c-a3fed4cc6e36} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 0, should be 2: In scope SELECT max(multiply()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:41702) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT max(multiply());), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:25.771878 [ 23635 ] {a969c79c-209b-4710-b30c-a3fed4cc6e36} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 0, should be 2: In scope SELECT max(multiply()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:25.773128 [ 23635 ] {faead4ed-ceb7-4315-8961-e2c427998cf1} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT min(multiply(1, 2, 3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:41702) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT min(multiply(1, 2 ,3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:25.773235 [ 23635 ] {faead4ed-ceb7-4315-8961-e2c427998cf1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT min(multiply(1, 2, 3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:25.800660 [ 23635 ] {47c448ed-cf36-4792-9a75-0e250772fceb} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 0, should be 2: In scope SELECT sum(plus() + multiply()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:41702) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT sum(plus() + multiply());), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:15:25.800914 [ 23635 ] {47c448ed-cf36-4792-9a75-0e250772fceb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 0, should be 2: In scope SELECT sum(plus() + multiply()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:15:25.803231 [ 23635 ] {c80f841e-8f04-4064-8036-262e4a74a7e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT sum((42 * 3) + multiply(42)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:41702) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT sum(plus(multiply(42, 3), multiply(42)));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:15:25.803342 [ 23635 ] {c80f841e-8f04-4064-8036-262e4a74a7e9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT sum((42 * 3) + multiply(42)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:15:25.971854 [ 23590 ] {15594dc9-28e6-40b8-8f1d-924e432753ae} executeQuery: Code: 507. DB::Exception: Sharding key is not deterministic. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.3.12.76.altinitystable) (from [::1]:41782) (comment: 01320_optimize_skip_unused_shards_no_non_deterministic.sql) (in query: select * from dist_01320 where key = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190beb 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fa4a 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:25.972033 [ 23590 ] {15594dc9-28e6-40b8-8f1d-924e432753ae} TCPHandler: Code: 507. DB::Exception: Sharding key is not deterministic. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190beb 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fa4a 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.072276 [ 12525 ] {b6ea713b-29e1-4950-a7ca-3052c1611be6} executeQuery: Code: 507. DB::Exception: Sharding key sub_key is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.3.12.76.altinitystable) (from [::1]:41808) (comment: 01319_optimize_skip_unused_shards_nesting.sql) (in query: select * from dist_01319 where key = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fa4a 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 11. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:76: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb48c1 12. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 13. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 19. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.072477 [ 12525 ] {b6ea713b-29e1-4950-a7ca-3052c1611be6} TCPHandler: Code: 507. DB::Exception: Sharding key sub_key is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000032190b3a 5. ./build_docker/./src/Storages/StorageDistributed.cpp:441: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003218e0e3 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fa4a 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 11. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:76: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb48c1 12. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 13. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 19. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.245152 [ 1374 ] {} ReadWriteBufferFromHTTP: Failed to make request to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2Ftest_nmtwt114%2Fr%2Freplicas%2Fr1&part=all_0_0_0&client_protocol_version=8&compress=false' redirect to 'http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2Ftest_nmtwt114%2Fr%2Freplicas%2Fr1&part=all_0_0_0&client_protocol_version=8&compress=false'. Error: 'DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2Ftest_nmtwt114%2Fr%2Freplicas%2Fr1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable)'. Failed at try 1/1. 2025.03.05 21:15:26.245441 [ 1374 ] {} test_nmtwt114.r2 (fcc684d6-ff55-4c12-853f-813f10fb2a16): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://9c65bcb792da:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2Ftest_nmtwt114%2Fr%2Freplicas%2Fr1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 Internal Server Error, body: Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 24.3.12.76.altinitystable). (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, String const&) @ 0x0000000024ab6109 4. ./src/IO/HTTPCommon.h:32: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000024ab5ea6 5. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000024ab5994 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000002906940e 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 14. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 15. ./build_docker/./src/Storages/MergeTree/DataPartsExchange.cpp:507: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000003295f8b7 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003256b6cf 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageReplicatedMergeTree::fetchPart(String const&, std::shared_ptr const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool) @ 0x000000003241e4a8 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000003240b599 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000323efc67 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032566b20 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000032fc1a3b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003245abb2 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000003259c9d9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:294: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000032ad94cf 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000032ada144 26. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 27. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 28. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:26.566607 [ 12525 ] {4db7ccc2-9d61-4b20-b4e1-a5eca732d41a} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for function aes_decrypt_mysql provided 0, expected 3 to 4 ('mode' : decryption mode string, 'input' : ciphertext, 'key' : decryption key binary string, ['IV' : Initialization vector binary string]): In scope SELECT aes_decrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: --- aes_decrypt_mysql(string, key, block_mode[, init_vector, AAD]) -- The MySQL-compatitable encryption, only ecb, cbc and ofb modes are supported, -- just like for MySQL -- https://dev.mysql.com/doc/refman/8.0/en/encryption-functions.html#function_aes-encrypt -- https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_block_encryption_mode -- Please note that for keys that exceed mode-specific length, keys are folded in a MySQL-specific way, -- meaning that whole key is used, but effective key length is still determined by mode. -- when key doesn't exceed the default mode length, ecryption result equals with AES_encypt() ----------------------------------------------------------------------------------------- -- error cases ----------------------------------------------------------------------------------------- SELECT aes_decrypt_mysql();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001971792b 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.566837 [ 12525 ] {4db7ccc2-9d61-4b20-b4e1-a5eca732d41a} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for function aes_decrypt_mysql provided 0, expected 3 to 4 ('mode' : decryption mode string, 'input' : ciphertext, 'key' : decryption key binary string, ['IV' : Initialization vector binary string]): In scope SELECT aes_decrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001971792b 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.569555 [ 12525 ] {664f0cd3-001c-486d-806f-23dbda093cc7} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for function aes_decrypt_mysql provided 1 (String), expected 3 to 4 ('mode' : decryption mode string, 'input' : ciphertext, 'key' : decryption key binary string, ['IV' : Initialization vector binary string]): In scope SELECT aes_decrypt_mysql('aes-128-ecb'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT aes_decrypt_mysql('aes-128-ecb');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001971792b 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.569733 [ 12525 ] {664f0cd3-001c-486d-806f-23dbda093cc7} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for function aes_decrypt_mysql provided 1 (String), expected 3 to 4 ('mode' : decryption mode string, 'input' : ciphertext, 'key' : decryption key binary string, ['IV' : Initialization vector binary string]): In scope SELECT aes_decrypt_mysql('aes-128-ecb'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001971792b 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.571644 [ 12525 ] {f00b2e25-d16a-4180-ad78-b12a1f6ee4fd} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for function aes_decrypt_mysql provided 2 (String, String), expected 3 to 4 ('mode' : decryption mode string, 'input' : ciphertext, 'key' : decryption key binary string, ['IV' : Initialization vector binary string]): In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001971792b 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.571794 [ 12525 ] {f00b2e25-d16a-4180-ad78-b12a1f6ee4fd} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for function aes_decrypt_mysql provided 2 (String, String), expected 3 to 4 ('mode' : decryption mode string, 'input' : ciphertext, 'key' : decryption key binary string, ['IV' : Initialization vector binary string]): In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001971792b 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.606400 [ 12525 ] {5934031f-80f4-433c-9ddb-9274135f5e41} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'mode' of function aes_decrypt_mysql, expected decryption mode string, got UInt16: In scope SELECT aes_decrypt_mysql(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT aes_decrypt_mysql(789, '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001971792b 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.641080 [ 12525 ] {5934031f-80f4-433c-9ddb-9274135f5e41} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'mode' of function aes_decrypt_mysql, expected decryption mode string, got UInt16: In scope SELECT aes_decrypt_mysql(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001971792b 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.641074 [ 14920 ] {4fb0f202-9216-496e-9c52-75b827d7ddef} executeQuery: Code: 42. DB::Exception: mapAdd accepts at least two maps or map tuples: In scope SELECT mapAdd(map(1, 1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:41896) (comment: 01318_map_add_map_subtract_on_map_type.sql) (in query: -- mapAdd select mapAdd(map(1, 1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002402c74c 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.673935 [ 48602 ] {f8be2f69-c409-4b24-878f-b43f05d93288} executeQuery: Code: 43. DB::Exception: mapAdd only accepts maps: In scope SELECT mapAdd([1], [1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:41912) (comment: 01318_map_add_map_subtract.sql) (in query: -- mapAdd select mapAdd([1], [1]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002402d97a 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.674022 [ 14920 ] {4fb0f202-9216-496e-9c52-75b827d7ddef} TCPHandler: Code: 42. DB::Exception: mapAdd accepts at least two maps or map tuples: In scope SELECT mapAdd(map(1, 1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002402c74c 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.674221 [ 48602 ] {f8be2f69-c409-4b24-878f-b43f05d93288} TCPHandler: Code: 43. DB::Exception: mapAdd only accepts maps: In scope SELECT mapAdd([1], [1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002402d97a 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.720484 [ 12525 ] {b885ed57-85d5-4874-b794-e542b7b6ae69} executeQuery: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT aes_decrypt_mysql('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT aes_decrypt_mysql('blah blah blah', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019717364 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:26.720534 [ 48602 ] {fc8102ee-06ef-461f-bc5e-2cef47234300} executeQuery: Code: 42. DB::Exception: mapAdd accepts at least two maps or map tuples: In scope SELECT mapAdd(([1], [1])). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:41912) (comment: 01318_map_add_map_subtract.sql) (in query: select mapAdd(([1], [1]));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002402c74c 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.750816 [ 14920 ] {96053505-ef28-4c46-b49a-144a8d4dda30} executeQuery: Code: 43. DB::Exception: Expected same UInt8 type for all keys in mapAdd: In scope SELECT mapAdd(map(1, 1), m) FROM mapop_test. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:41896) (comment: 01318_map_add_map_subtract_on_map_type.sql) (in query: select mapAdd(map(1, 1), m) from mapop_test;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000002412f927 5. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002402cb5b 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.750830 [ 12525 ] {b885ed57-85d5-4874-b794-e542b7b6ae69} TCPHandler: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT aes_decrypt_mysql('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019717364 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:26.750901 [ 48602 ] {fc8102ee-06ef-461f-bc5e-2cef47234300} TCPHandler: Code: 42. DB::Exception: mapAdd accepts at least two maps or map tuples: In scope SELECT mapAdd(([1], [1])). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002402c74c 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.751075 [ 14920 ] {96053505-ef28-4c46-b49a-144a8d4dda30} TCPHandler: Code: 43. DB::Exception: Expected same UInt8 type for all keys in mapAdd: In scope SELECT mapAdd(map(1, 1), m) FROM mapop_test. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000002412f927 5. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002402cb5b 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.753452 [ 12525 ] {1eaa0c99-885d-4327-befe-26c37363818b} executeQuery: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT aes_decrypt_mysql('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT aes_decrypt_mysql('des-ede3-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019717364 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:26.753610 [ 12525 ] {1eaa0c99-885d-4327-befe-26c37363818b} TCPHandler: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT aes_decrypt_mysql('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019717364 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:26.785471 [ 48602 ] {c068ffd0-fea5-4a23-a3a7-e599364f6a0f} executeQuery: Code: 43. DB::Exception: Expected same UInt8 type for all keys in mapAdd: In scope SELECT mapAdd(([1], [1]), map) FROM map_test. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:41912) (comment: 01318_map_add_map_subtract.sql) (in query: select mapAdd(([1], [1]), map) from map_test;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000002412f927 5. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002402b56b 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.815860 [ 12525 ] {3bf94acd-02a5-4620-89e4-9d22e008be1e} executeQuery: Code: 36. DB::Exception: Unsupported cipher mode: In scope SELECT aes_decrypt_mysql('aes-128-gcm', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT aes_decrypt_mysql('aes-128-gcm', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000197174f8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:26.815878 [ 48602 ] {c068ffd0-fea5-4a23-a3a7-e599364f6a0f} TCPHandler: Code: 43. DB::Exception: Expected same UInt8 type for all keys in mapAdd: In scope SELECT mapAdd(([1], [1]), map) FROM map_test. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000002412f927 5. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002402b56b 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.816035 [ 12525 ] {3bf94acd-02a5-4620-89e4-9d22e008be1e} TCPHandler: Code: 36. DB::Exception: Unsupported cipher mode: In scope SELECT aes_decrypt_mysql('aes-128-gcm', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000197174f8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:26.818309 [ 12525 ] {113680f1-1859-41bd-b862-da5edc2b5f7a} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'mode' of function decrypt, expected decryption mode string, got UInt16: In scope SELECT decrypt(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT decrypt(789, '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa9974b 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.818431 [ 12525 ] {113680f1-1859-41bd-b862-da5edc2b5f7a} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'mode' of function decrypt, expected decryption mode string, got UInt16: In scope SELECT decrypt(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa9974b 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.850184 [ 48602 ] {fad8036f-3447-44e7-bd31-064d4c93fc96} executeQuery: Code: 43. DB::Exception: All value types in mapAdd should be promotable to UInt64, got Int64: In scope SELECT mapAdd(([toUInt64(1)], [1]), map) FROM map_test. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:41912) (comment: 01318_map_add_map_subtract.sql) (in query: select mapAdd(([toUInt64(1)], [1]), map) from map_test;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000002412fc71 5. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002402b56b 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.883041 [ 12525 ] {846dda81-0902-4a09-9ed9-d8ad2fe07e84} executeQuery: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT decrypt('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT decrypt('blah blah blah', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa99078 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:26.908428 [ 14920 ] {85b12e6d-50de-454c-bde0-79a5d0f9b3c0} executeQuery: Code: 43. DB::Exception: All value types in mapAdd should be either or float or integer: In scope SELECT mapAdd(map(1, toFloat64(1.1), 2, 1), map(1, 1, 2, 1)) AS res, toTypeName(res). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:41896) (comment: 01318_map_add_map_subtract_on_map_type.sql) (in query: select mapAdd(map(1, toFloat64(1.1), 2, 1), map(1, 1, 2, 1)) as res, toTypeName(res);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000002412fa65 5. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002402cb5b 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.908478 [ 48602 ] {fad8036f-3447-44e7-bd31-064d4c93fc96} TCPHandler: Code: 43. DB::Exception: All value types in mapAdd should be promotable to UInt64, got Int64: In scope SELECT mapAdd(([toUInt64(1)], [1]), map) FROM map_test. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000002412fc71 5. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002402b56b 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.908517 [ 12525 ] {846dda81-0902-4a09-9ed9-d8ad2fe07e84} TCPHandler: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT decrypt('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa99078 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:26.908701 [ 14920 ] {85b12e6d-50de-454c-bde0-79a5d0f9b3c0} TCPHandler: Code: 43. DB::Exception: All value types in mapAdd should be either or float or integer: In scope SELECT mapAdd(map(1, toFloat64(1.1), 2, 1), map(1, 1, 2, 1)) AS res, toTypeName(res). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000002412fa65 5. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002402cb5b 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.911290 [ 12525 ] {bf164966-66fa-4ca3-9640-1d911f0c28a1} executeQuery: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT decrypt('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT decrypt('des-ede3-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa99078 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:26.911420 [ 12525 ] {bf164966-66fa-4ca3-9640-1d911f0c28a1} TCPHandler: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT decrypt('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa99078 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:26.942236 [ 48602 ] {971183ff-c975-4320-b117-3e660d9b7506} executeQuery: Code: 42. DB::Exception: Key and value array should have same amount of elements. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:41912) (comment: 01318_map_add_map_subtract.sql) (in query: select mapAdd(([toUInt64(1), 2], [toInt32(1)]), map) from map_test;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000024029eb1 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.942343 [ 12525 ] {90ad3799-a14a-42b0-8550-d707c523ef4f} executeQuery: Code: 43. DB::Exception: Illegal type of argument #3 'key' of function aes_decrypt_mysql, expected decryption key binary string, got UInt16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001971792b 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.942472 [ 48602 ] {971183ff-c975-4320-b117-3e660d9b7506} TCPHandler: Code: 42. DB::Exception: Key and value array should have same amount of elements. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000024029eb1 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.942661 [ 12525 ] {90ad3799-a14a-42b0-8550-d707c523ef4f} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #3 'key' of function aes_decrypt_mysql, expected decryption key binary string, got UInt16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001971792b 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:26.990577 [ 12525 ] {1445e2e9-61d9-41af-81a2-4b6edf34b185} executeQuery: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018820822 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x0000000019718396 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019716faa 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:26.990836 [ 12525 ] {1445e2e9-61d9-41af-81a2-4b6edf34b185} TCPHandler: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018820822 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x0000000019718396 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019716faa 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:27.015739 [ 12525 ] {b5f03cea-a6e4-475b-af4a-e1555088308a} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for function decrypt provided 2 (String, String), expected 3 to 5 ('mode' : decryption mode string, 'input' : ciphertext, 'key' : decryption key binary string, ['IV' : Initialization vector binary string, 'AAD' : Additional authenticated data binary string for GCM mode]): In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT decrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa9974b 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:27.057625 [ 12525 ] {b5f03cea-a6e4-475b-af4a-e1555088308a} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for function decrypt provided 2 (String, String), expected 3 to 5 ('mode' : decryption mode string, 'input' : ciphertext, 'key' : decryption key binary string, ['IV' : Initialization vector binary string, 'AAD' : Additional authenticated data binary string for GCM mode]): In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa9974b 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:27.057620 [ 48602 ] {cd4a6a36-46cd-4c1f-a35e-115ebeabb3d9} executeQuery: Code: 43. DB::Exception: Illegal column type Float32 for keys in arguments of function mapAdd: In scope SELECT mapAdd(([toFloat32(1), 2], [toFloat64(1.1), 1]), ([toFloat32(1), 2], [2.2, 1])) AS res, toTypeName(res). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:41912) (comment: 01318_map_add_map_subtract.sql) (in query: select mapAdd(([toFloat32(1), 2], [toFloat64(1.1), 1]), ([toFloat32(1), 2], [2.2, 1])) as res, toTypeName(res);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002402aa4e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:27.058066 [ 48602 ] {cd4a6a36-46cd-4c1f-a35e-115ebeabb3d9} TCPHandler: Code: 43. DB::Exception: Illegal column type Float32 for keys in arguments of function mapAdd: In scope SELECT mapAdd(([toFloat32(1), 2], [toFloat64(1.1), 1]), ([toFloat32(1), 2], [2.2, 1])) AS res, toTypeName(res). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002402aa4e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:27.061065 [ 12525 ] {de31bcc1-ed28-4814-beac-39a142923c2a} executeQuery: Code: 43. DB::Exception: Illegal type of argument #3 'key' of function decrypt, expected decryption key binary string, got UInt16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT decrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa9974b 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:27.061224 [ 12525 ] {de31bcc1-ed28-4814-beac-39a142923c2a} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #3 'key' of function decrypt, expected decryption key binary string, got UInt16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa9974b 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:27.102006 [ 48602 ] {4bb6edb7-82af-488d-b2be-e8823c4e2b5f} executeQuery: Code: 43. DB::Exception: All value types in mapAdd should be either or float or integer: In scope SELECT mapAdd(([1, 2], [toFloat64(1.1), 1]), ([1, 2], [1, 1])) AS res, toTypeName(res). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:41912) (comment: 01318_map_add_map_subtract.sql) (in query: select mapAdd(([1, 2], [toFloat64(1.1), 1]), ([1, 2], [1, 1])) as res, toTypeName(res);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000002412fa65 5. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002402b56b 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:27.133620 [ 12525 ] {8ef4794c-5592-4670-8c3f-5f4252d8ca6e} executeQuery: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT decrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018820822 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001aa9ac16 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa98caa 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:27.133668 [ 48602 ] {4bb6edb7-82af-488d-b2be-e8823c4e2b5f} TCPHandler: Code: 43. DB::Exception: All value types in mapAdd should be either or float or integer: In scope SELECT mapAdd(([1, 2], [toFloat64(1.1), 1]), ([1, 2], [1, 1])) AS res, toTypeName(res). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000002412fa65 5. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002402b56b 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:27.133856 [ 12525 ] {8ef4794c-5592-4670-8c3f-5f4252d8ca6e} TCPHandler: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018820822 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001aa9ac16 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa98caa 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:27.136294 [ 12525 ] {4344edee-a4a3-47f5-adeb-def587c9f31e} executeQuery: Code: 36. DB::Exception: Invalid key size: 36 expected 16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT decrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018820822 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001aa9ac16 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa98caa 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:27.136441 [ 12525 ] {4344edee-a4a3-47f5-adeb-def587c9f31e} TCPHandler: Code: 36. DB::Exception: Invalid key size: 36 expected 16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018820822 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001aa9ac16 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa98caa 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:27.160289 [ 12525 ] {c0c1f313-27da-4a29-82a3-b00f471da1c5} executeQuery: Code: 43. DB::Exception: Illegal type of argument #4 'IV' of function aes_decrypt_mysql, expected Initialization vector binary string, got UInt16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001971792b 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:27.160612 [ 12525 ] {c0c1f313-27da-4a29-82a3-b00f471da1c5} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #4 'IV' of function aes_decrypt_mysql, expected Initialization vector binary string, got UInt16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001971792b 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:27.192129 [ 12525 ] {7b3dfde9-6fea-4a88-a999-3daee5074bb2} executeQuery: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018820822 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x0000000019718396 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000197170e0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:27.192326 [ 12525 ] {7b3dfde9-6fea-4a88-a999-3daee5074bb2} TCPHandler: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018820822 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x0000000019718396 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000197170e0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:27.216370 [ 12525 ] {bee14c03-852c-4ef3-bf12-bc2351a881ee} executeQuery: Code: 43. DB::Exception: Illegal type of argument #4 'IV' of function decrypt, expected Initialization vector binary string, got UInt16: In scope SELECT decrypt('aes-128-cbc', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT decrypt('aes-128-cbc', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa9974b 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:27.216617 [ 12525 ] {bee14c03-852c-4ef3-bf12-bc2351a881ee} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #4 'IV' of function decrypt, expected Initialization vector binary string, got UInt16: In scope SELECT decrypt('aes-128-cbc', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa9974b 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:27.247498 [ 12525 ] {59b3b49b-d0fe-4725-bb38-d3325c1b63e6} executeQuery: Code: 36. DB::Exception: Invalid IV size: 42 expected 16: In scope SELECT decrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT decrypt('aes-128-cbc', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001aa9af16 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa98df6 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:27.247741 [ 12525 ] {59b3b49b-d0fe-4725-bb38-d3325c1b63e6} TCPHandler: Code: 36. DB::Exception: Invalid IV size: 42 expected 16: In scope SELECT decrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001aa9af16 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa98df6 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:27.250118 [ 12525 ] {4c43070e-fa12-43a9-bf8a-f0e17a94b93a} executeQuery: Code: 36. DB::Exception: Invalid IV size: 2 expected 16: In scope SELECT decrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT decrypt('aes-128-cbc', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001aa9af16 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa98df6 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:27.250262 [ 12525 ] {4c43070e-fa12-43a9-bf8a-f0e17a94b93a} TCPHandler: Code: 36. DB::Exception: Invalid IV size: 2 expected 16: In scope SELECT decrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000019718882 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001aa9af16 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa98df6 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:27.252036 [ 12525 ] {c48deec5-8fa0-4a8d-a7d3-31ce8398f766} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for function aes_decrypt_mysql provided 5 (String, String, String, String, UInt16), expected 3 to 4 ('mode' : decryption mode string, 'input' : ciphertext, 'key' : decryption key binary string, ['IV' : Initialization vector binary string]): In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001971792b 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:27.252156 [ 12525 ] {c48deec5-8fa0-4a8d-a7d3-31ce8398f766} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for function aes_decrypt_mysql provided 5 (String, String, String, String, UInt16), expected 3 to 4 ('mode' : decryption mode string, 'input' : ciphertext, 'key' : decryption key binary string, ['IV' : Initialization vector binary string]): In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&, unsigned long&&, String&&, String&&, String&&) @ 0x000000002e854b25 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851708 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001971792b 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:27.254123 [ 12525 ] {4b6e444c-2d39-4a57-8992-84e4ff217081} executeQuery: Code: 43. DB::Exception: Illegal type of argument #5 'AAD' of function decrypt, expected Additional authenticated data binary string for GCM mode, got UInt16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT decrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa9974b 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:27.254301 [ 12525 ] {4b6e444c-2d39-4a57-8992-84e4ff217081} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #5 'AAD' of function decrypt, expected Additional authenticated data binary string for GCM mode, got UInt16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa9974b 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:27.255825 [ 12525 ] {e9a2c863-6b47-46e3-8740-7357e174b8a4} executeQuery: Code: 43. DB::Exception: Illegal type of argument #5 'AAD' of function decrypt, expected Additional authenticated data binary string for GCM mode, got UInt16: In scope SELECT decrypt('aes-128-gcm', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT decrypt('aes-128-gcm', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa9974b 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:27.255941 [ 12525 ] {e9a2c863-6b47-46e3-8740-7357e174b8a4} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #5 'AAD' of function decrypt, expected Additional authenticated data binary string for GCM mode, got UInt16: In scope SELECT decrypt('aes-128-gcm', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001aa9974b 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:27.284147 [ 12525 ] {fcacb6e2-048f-4898-837c-a1a6b7035d6d} executeQuery: Code: 454. DB::Exception: Failed to decrypt. OpenSSL error code: 503316603: In scope SELECT ignore(decrypt('aes-128-ecb', '[HIDDEN]')). (OPENSSL_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT ignore(decrypt('aes-128-ecb', '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned int&&) @ 0x00000000180bc352 4. DB::OpenSSLDetails::onError(String) @ 0x00000000180bc16e 5. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001aa9ae5c 6. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa98caa 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:15:27.284418 [ 12525 ] {fcacb6e2-048f-4898-837c-a1a6b7035d6d} TCPHandler: Code: 454. DB::Exception: Failed to decrypt. OpenSSL error code: 503316603: In scope SELECT ignore(decrypt('aes-128-ecb', '[HIDDEN]')). (OPENSSL_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned int&&) @ 0x00000000180bc352 4. DB::OpenSSLDetails::onError(String) @ 0x00000000180bc16e 5. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001aa9ae5c 6. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa98caa 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:15:27.286709 [ 12525 ] {ba5b992b-0c02-4aea-a17e-f020313eb59c} executeQuery: Code: 454. DB::Exception: Failed to decrypt. OpenSSL error code: 503316603: In scope SELECT ignore(decrypt('aes-128-cbc', '[HIDDEN]')). (OPENSSL_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT ignore(decrypt('aes-128-cbc', '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned int&&) @ 0x00000000180bc352 4. DB::OpenSSLDetails::onError(String) @ 0x00000000180bc16e 5. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001aa9ae5c 6. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa98caa 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:15:27.286832 [ 12525 ] {ba5b992b-0c02-4aea-a17e-f020313eb59c} TCPHandler: Code: 454. DB::Exception: Failed to decrypt. OpenSSL error code: 503316603: In scope SELECT ignore(decrypt('aes-128-cbc', '[HIDDEN]')). (OPENSSL_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned int&&) @ 0x00000000180bc352 4. DB::OpenSSLDetails::onError(String) @ 0x00000000180bc16e 5. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001aa9ae5c 6. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa98caa 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:15:27.451748 [ 48602 ] {f4a547f7-f73d-43ca-aa95-970ccef210b7} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: neither Date nor Time was parsed successfully: In scope SELECT parseDateTimeBestEffort(''). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:42018) (comment: 01313_parse_date_time_best_effort_null_zero.sql) (in query: SELECT parseDateTimeBestEffort('');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*) @ 0x000000002474a4f7 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionConvertFromString::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) const @ 0x000000001872d344 6. DB::(anonymous namespace)::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018729ca0 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:15:27.494773 [ 48602 ] {f4a547f7-f73d-43ca-aa95-970ccef210b7} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: neither Date nor Time was parsed successfully: In scope SELECT parseDateTimeBestEffort(''). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*) @ 0x000000002474a4f7 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionConvertFromString::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) const @ 0x000000001872d344 6. DB::(anonymous namespace)::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018729ca0 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:15:27.494773 [ 12525 ] {f649492c-999c-430a-879c-56b81aacb612} executeQuery: Code: 454. DB::Exception: Failed to decrypt. OpenSSL error code: 0: while executing 'FUNCTION and(greater(__table1.user_id, 0_UInt8) :: 3, equals(decrypt('aes-256-gcm'_String, __table1.encrypted, 'keykeykeykeykeykeykeykeykeykey02'_String, __table1.iv), 'value2'_String) :: 2) -> and(greater(__table1.user_id, 0_UInt8), equals(decrypt('aes-256-gcm'_String, __table1.encrypted, 'keykeykeykeykeykeykeykeykeykey02'_String, __table1.iv), 'value2'_String)) UInt8 : 7'. (OPENSSL_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:41894) (comment: 01318_decrypt.sql) (in query: SELECT dt, user_id FROM decrypt_null WHERE (user_id > 0) AND (decrypt('aes-256-gcm', '[HIDDEN]') = 'value2')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned int&&) @ 0x00000000180bc352 4. DB::OpenSSLDetails::onError(String) @ 0x00000000180bc16e 5. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001aa9b066 6. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa98df6 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ColumnFunction::reduce() const @ 0x0000000031b24117 13. ./build_docker/./src/Columns/ColumnFunction.cpp:311: DB::ColumnFunction::reduce() const @ 0x0000000031b23d27 14. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000032061bd9 15. ./contrib/llvm-project/libcxx/include/vector:537: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::executeShortCircuit(std::vector>&, std::shared_ptr const&) const @ 0x000000002e8c0c24 16. ./build_docker/./src/Functions/FunctionsLogical.cpp:0: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002e8bb32a 17. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 20. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 23. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000033b59e3a 24. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:265: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000033b598fa 25. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 31. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 2025.03.05 21:15:27.495157 [ 12525 ] {f649492c-999c-430a-879c-56b81aacb612} TCPHandler: Code: 454. DB::Exception: Failed to decrypt. OpenSSL error code: 0: while executing 'FUNCTION and(greater(__table1.user_id, 0_UInt8) :: 3, equals(decrypt('aes-256-gcm'_String, __table1.encrypted, 'keykeykeykeykeykeykeykeykeykey02'_String, __table1.iv), 'value2'_String) :: 2) -> and(greater(__table1.user_id, 0_UInt8), equals(decrypt('aes-256-gcm'_String, __table1.encrypted, 'keykeykeykeykeykeykeykeykeykey02'_String, __table1.iv), 'value2'_String)) UInt8 : 7'. (OPENSSL_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned int&&) @ 0x00000000180bc352 4. DB::OpenSSLDetails::onError(String) @ 0x00000000180bc16e 5. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001aa9b066 6. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa98df6 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ColumnFunction::reduce() const @ 0x0000000031b24117 13. ./build_docker/./src/Columns/ColumnFunction.cpp:311: DB::ColumnFunction::reduce() const @ 0x0000000031b23d27 14. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000032061bd9 15. ./contrib/llvm-project/libcxx/include/vector:537: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::executeShortCircuit(std::vector>&, std::shared_ptr const&) const @ 0x000000002e8c0c24 16. ./build_docker/./src/Functions/FunctionsLogical.cpp:0: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002e8bb32a 17. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 20. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 23. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000033b59e3a 24. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:265: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000033b598fa 25. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 31. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 2025.03.05 21:15:27.561433 [ 48602 ] {0b2f8ba2-2dac-461b-afae-90a1cd039403} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: neither Date nor Time was parsed successfully: In scope SELECT parseDateTime64BestEffort(''). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:42018) (comment: 01313_parse_date_time_best_effort_null_zero.sql) (in query: SELECT parseDateTime64BestEffort('');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*) @ 0x000000002474a4f7 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:674: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000002474fc4c 6. DB::(anonymous namespace)::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001874c420 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:15:27.561590 [ 48602 ] {0b2f8ba2-2dac-461b-afae-90a1cd039403} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: neither Date nor Time was parsed successfully: In scope SELECT parseDateTime64BestEffort(''). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:0: void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*) @ 0x000000002474a4f7 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:674: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000002474fc4c 6. DB::(anonymous namespace)::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001874c420 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:15:27.597111 [ 48602 ] {11afa970-d0e2-40e9-9c55-41fe43ce6e50} executeQuery: Code: 41. DB::Exception: Cannot parse datetime: Cannot parse DateTime from String: In scope SELECT toDateTime(''). (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:42018) (comment: 01313_parse_date_time_best_effort_null_zero.sql) (in query: SELECT toDateTime('');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::readDateTimeTextImpl(long&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000187c26d6 5. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000184b2df9 6. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018496743 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:15:27.597321 [ 48602 ] {11afa970-d0e2-40e9-9c55-41fe43ce6e50} TCPHandler: Code: 41. DB::Exception: Cannot parse datetime: Cannot parse DateTime from String: In scope SELECT toDateTime(''). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::readDateTimeTextImpl(long&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000187c26d6 5. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000184b2df9 6. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018496743 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:15:27.803739 [ 48602 ] {8a19d7d0-8430-4b7e-9d8a-8dc38671ee40} executeQuery: Code: 53. DB::Exception: Cannot convert string 1.0 to type UInt8: In scope SELECT 1 = '1.0'. (TYPE_MISMATCH) (version 24.3.12.76.altinitystable) (from [::1]:42046) (comment: 01311_comparison_with_constant_string.sql) (in query: -- it should work but it doesn't. SELECT 1 = '1.0';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169a592 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1a2f0a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1835c5 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:27.803949 [ 48602 ] {8a19d7d0-8430-4b7e-9d8a-8dc38671ee40} TCPHandler: Code: 53. DB::Exception: Cannot convert string 1.0 to type UInt8: In scope SELECT 1 = '1.0'. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169a592 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1a2f0a 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1835c5 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:27.864880 [ 48602 ] {c31317f1-6f5b-4a4e-86ce-30496d9efe5c} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: while converting '' to UInt8: In scope SELECT 0 = ''. (ATTEMPT_TO_READ_AFTER_EOF) (version 24.3.12.76.altinitystable) (from [::1]:42046) (comment: 01311_comparison_with_constant_string.sql) (in query: SELECT 0 = '';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x00000000247381ce 5. ./src/IO/ReadHelpers.h:524: void DB::readIntTextUnsafe(unsigned long&, DB::ReadBuffer&) @ 0x000000002f64cc65 6. ./src/Common/assert_cast.h:50: DB::SerializationNumber::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000002f64c662 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031699857 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 9. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1a2f0a 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1835c5 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:15:27.865092 [ 48602 ] {c31317f1-6f5b-4a4e-86ce-30496d9efe5c} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: while converting '' to UInt8: In scope SELECT 0 = ''. (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x00000000247381ce 5. ./src/IO/ReadHelpers.h:524: void DB::readIntTextUnsafe(unsigned long&, DB::ReadBuffer&) @ 0x000000002f64cc65 6. ./src/Common/assert_cast.h:50: DB::SerializationNumber::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000002f64c662 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031699857 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 9. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1a2f0a 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1835c5 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:15:27.916747 [ 14920 ] {c581f021-b856-4b29-993a-0af70535e7e8} executeQuery: Code: 691. DB::Exception: Unknown element 'xyz' for enum: while converting 'xyz' to Enum8('hello' = 1, 'world' = 2). (UNKNOWN_ELEMENT_OF_ENUM) (version 24.3.12.76.altinitystable) (from [::1]:42062) (comment: 01310_enum_comparison.sql) (in query: SELECT count() FROM enum WHERE x = 'xyz';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/DataTypes/EnumValues.cpp:0: DB::EnumValues<_BitInt(8)>::getValue(StringRef, bool) const @ 0x000000002f538d3c 5. ./build_docker/./src/DataTypes/Serializations/SerializationEnum.cpp:99: DB::SerializationEnum<_BitInt(8)>::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e88aa 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031699857 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 8. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1a2f0a 9. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1835c5 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 18. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 19. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 20. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 21. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:27.916966 [ 14920 ] {c581f021-b856-4b29-993a-0af70535e7e8} TCPHandler: Code: 691. DB::Exception: Unknown element 'xyz' for enum: while converting 'xyz' to Enum8('hello' = 1, 'world' = 2). (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001aa7cd0a 4. ./build_docker/./src/DataTypes/EnumValues.cpp:0: DB::EnumValues<_BitInt(8)>::getValue(StringRef, bool) const @ 0x000000002f538d3c 5. ./build_docker/./src/DataTypes/Serializations/SerializationEnum.cpp:99: DB::SerializationEnum<_BitInt(8)>::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5e88aa 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031699857 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 8. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1a2f0a 9. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1835c5 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 18. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 19. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 20. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 21. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:28.070888 [ 14920 ] {1fe87a3b-1103-4cdf-b584-c787a643c7ee} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonAreaCartesian([]). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:42098) (comment: 01308_polygon_area.sql) (in query: SELECT polygonAreaCartesian([]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionPolygonArea>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020dc8629 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:28.071095 [ 14920 ] {1fe87a3b-1103-4cdf-b584-c787a643c7ee} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonAreaCartesian([]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionPolygonArea>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020dc8629 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:29.202370 [ 23562 ] {5b902791-5133-4a24-87a5-0f1602025c28} executeQuery: Code: 47. DB::Exception: Identifier '__table1.dummy1' cannot be resolved from table with name __table1. In scope SELECT __table1.CounterID AS CounterID, __table1.dummy1 AS dummy1 FROM test_laro9g7m.merge_distributed1 AS __table1 WHERE __table1.dummy1 != '' LIMIT _CAST(10, 'UInt64'). Maybe you meant: ['__table1.dummy']. (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:57126) (comment: 01297_alter_distributed.sql) (in query: SELECT `__table1`.`CounterID` AS `CounterID`, `__table1`.`dummy1` AS `dummy1` FROM `test_laro9g7m`.`merge_distributed1` AS `__table1` WHERE `__table1`.`dummy1` != '' LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000003091f2a1 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::(anonymous namespace)::TableExpressionData const&, DB::(anonymous namespace)::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000308d6d5b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7872 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./contrib/llvm-project/libcxx/include/vector:1457: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x0000000030866007 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000030865d25 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe6e4 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:29.202609 [ 23562 ] {5b902791-5133-4a24-87a5-0f1602025c28} TCPHandler: Code: 47. DB::Exception: Identifier '__table1.dummy1' cannot be resolved from table with name __table1. In scope SELECT __table1.CounterID AS CounterID, __table1.dummy1 AS dummy1 FROM test_laro9g7m.merge_distributed1 AS __table1 WHERE __table1.dummy1 != '' LIMIT _CAST(10, 'UInt64'). Maybe you meant: ['__table1.dummy']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000003091f2a1 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::(anonymous namespace)::TableExpressionData const&, DB::(anonymous namespace)::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000308d6d5b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7872 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./contrib/llvm-project/libcxx/include/vector:1457: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x0000000030866007 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000030865d25 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe6e4 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:29.206635 [ 3522 ] {923da52d-ec6f-4675-ab06-af57e5dc4093} executeQuery: Code: 47. DB::Exception: Received from localhost:9000. DB::Exception: Identifier '__table1.dummy1' cannot be resolved from table with name __table1. In scope SELECT __table1.CounterID AS CounterID, __table1.dummy1 AS dummy1 FROM test_laro9g7m.merge_distributed1 AS __table1 WHERE __table1.dummy1 != '' LIMIT _CAST(10, 'UInt64'). Maybe you meant: ['__table1.dummy']. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000003091f2a1 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::(anonymous namespace)::TableExpressionData const&, DB::(anonymous namespace)::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000308d6d5b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7872 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./contrib/llvm-project/libcxx/include/vector:1457: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x0000000030866007 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000030865d25 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe6e4 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 : While executing Remote. (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:57568) (comment: 01297_alter_distributed.sql) (in query: select CounterID, dummy1 from merge_distributed where dummy1 <> '' limit 10;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:15:29.211364 [ 3522 ] {923da52d-ec6f-4675-ab06-af57e5dc4093} TCPHandler: Code: 47. DB::Exception: Received from localhost:9000. DB::Exception: Identifier '__table1.dummy1' cannot be resolved from table with name __table1. In scope SELECT __table1.CounterID AS CounterID, __table1.dummy1 AS dummy1 FROM test_laro9g7m.merge_distributed1 AS __table1 WHERE __table1.dummy1 != '' LIMIT _CAST(10, 'UInt64'). Maybe you meant: ['__table1.dummy']. Stack trace: 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000003091f2a1 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::(anonymous namespace)::TableExpressionData const&, DB::(anonymous namespace)::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000308d6d5b 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTreeNode(DB::(anonymous namespace)::IdentifierLookup const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308c7872 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromJoinTree(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089e677 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b9da 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./contrib/llvm-project/libcxx/include/vector:1457: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x0000000030866007 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000030865d25 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe6e4 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 : While executing Remote. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000002470915e 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receiveException() const @ 0x000000003327c561 5. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000003328c0e6 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x00000000332f907e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44aad8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002f44a7a0 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:36: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f44a3f7 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f4486b9 2025.03.05 21:15:29.253886 [ 22858 ] {5c60832b-8f91-4262-873d-30ae2173c46e} executeQuery: Code: 433. DB::Exception: Delta codec argument must be unsigned integer. (ILLEGAL_CODEC_PARAMETER) (version 24.3.12.76.altinitystable) (from [::1]:57576) (comment: 01296_codecs_bad_arguments.sql) (in query: CREATE TABLE delta_table (`id` UInt64 CODEC(Delta(tuple()))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 15004, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.882835328578949, replace_long_file_name_to_hash = false, max_file_name_length = 23, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 180938613, compact_parts_max_granules_to_buffer = 159, compact_parts_merge_max_bytes_to_prefetch_part = 19465088, merge_max_block_size = 21044, old_parts_lifetime = 455., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 404011, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8187509186, index_granularity_bytes = 20933022, concurrent_part_removal_threshold = 51, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 48245, primary_key_compress_block_size = 53927), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Compression/CompressionCodecDelta.cpp:206: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000002f39ea8c 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:29.254080 [ 22858 ] {5c60832b-8f91-4262-873d-30ae2173c46e} TCPHandler: Code: 433. DB::Exception: Delta codec argument must be unsigned integer. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Compression/CompressionCodecDelta.cpp:206: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000002f39ea8c 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:29.273499 [ 22858 ] {070a6dd9-5f70-423f-ae7c-9391f80ce243} executeQuery: Code: 433. DB::Exception: ZSTD codec argument must be integer. (ILLEGAL_CODEC_PARAMETER) (version 24.3.12.76.altinitystable) (from [::1]:57576) (comment: 01296_codecs_bad_arguments.sql) (in query: CREATE TABLE zstd_table (`id` UInt64 CODEC(ZSTD(tuple()))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 15004, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.882835328578949, replace_long_file_name_to_hash = false, max_file_name_length = 23, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 180938613, compact_parts_max_granules_to_buffer = 159, compact_parts_merge_max_bytes_to_prefetch_part = 19465088, merge_max_block_size = 21044, old_parts_lifetime = 455., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 404011, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8187509186, index_granularity_bytes = 20933022, concurrent_part_removal_threshold = 51, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 48245, primary_key_compress_block_size = 53927), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Compression/CompressionCodecZSTD.cpp:99: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f395e0d 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:29.273717 [ 22858 ] {070a6dd9-5f70-423f-ae7c-9391f80ce243} TCPHandler: Code: 433. DB::Exception: ZSTD codec argument must be integer. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Compression/CompressionCodecZSTD.cpp:99: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f395e0d 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:29.293373 [ 22858 ] {7756f3ed-be55-4f5e-80b9-cc1051c925d9} executeQuery: Code: 433. DB::Exception: LZ4HC codec argument must be integer. (ILLEGAL_CODEC_PARAMETER) (version 24.3.12.76.altinitystable) (from [::1]:57576) (comment: 01296_codecs_bad_arguments.sql) (in query: CREATE TABLE lz4_table (`id` UInt64 CODEC(LZ4HC(tuple()))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 15004, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.882835328578949, replace_long_file_name_to_hash = false, max_file_name_length = 23, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 180938613, compact_parts_max_granules_to_buffer = 159, compact_parts_merge_max_bytes_to_prefetch_part = 19465088, merge_max_block_size = 21044, old_parts_lifetime = 455., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 404011, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8187509186, index_granularity_bytes = 20933022, concurrent_part_removal_threshold = 51, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 48245, primary_key_compress_block_size = 53927), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Compression/CompressionCodecLZ4.cpp:134: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f39354b 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:29.293649 [ 22858 ] {7756f3ed-be55-4f5e-80b9-cc1051c925d9} TCPHandler: Code: 433. DB::Exception: LZ4HC codec argument must be integer. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Compression/CompressionCodecLZ4.cpp:134: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f39354b 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:29.314024 [ 22858 ] {2bad40c5-4776-4b5a-86e9-f0787a35ea40} executeQuery: Code: 378. DB::Exception: Compression codec LZ4 cannot have arguments. (DATA_TYPE_CANNOT_HAVE_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:57576) (comment: 01296_codecs_bad_arguments.sql) (in query: CREATE TABLE lz4_table (`id` UInt64 CODEC(LZ4(tuple()))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 15004, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.882835328578949, replace_long_file_name_to_hash = false, max_file_name_length = 23, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 180938613, compact_parts_max_granules_to_buffer = 159, compact_parts_merge_max_bytes_to_prefetch_part = 19465088, merge_max_block_size = 21044, old_parts_lifetime = 455., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 404011, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8187509186, index_granularity_bytes = 20933022, concurrent_part_removal_threshold = 51, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 48245, primary_key_compress_block_size = 53927), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Compression/CompressionFactory.cpp:168: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl, std::function ()>)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f38b8c1 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:29.314278 [ 22858 ] {2bad40c5-4776-4b5a-86e9-f0787a35ea40} TCPHandler: Code: 378. DB::Exception: Compression codec LZ4 cannot have arguments. (DATA_TYPE_CANNOT_HAVE_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Compression/CompressionFactory.cpp:168: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl, std::function ()>)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002f38b8c1 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000307f0a23 6. ./contrib/llvm-project/libcxx/include/vector:1613: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5a38d1 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f5a3bb7 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000307ee37b 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b31f8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:31.625948 [ 48606 ] {c02d011e-e832-481f-977a-67b86f88cf74} executeQuery: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT toIntervalSecond(now64()). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:57940) (comment: 01291_unsupported_conversion_from_decimal.sql) (in query: SELECT toIntervalSecond(now64());), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018577d95 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001856e84f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:31.626125 [ 48606 ] {c02d011e-e832-481f-977a-67b86f88cf74} TCPHandler: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT toIntervalSecond(now64()). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018577d95 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001856e84f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:31.655860 [ 48606 ] {3988efd7-52fe-4c30-969a-fff43e1722c8} executeQuery: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT CAST(now64(), 'IntervalSecond'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:57940) (comment: 01291_unsupported_conversion_from_decimal.sql) (in query: SELECT CAST(now64() AS IntervalSecond);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018577d95 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001856e84f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 16. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 18. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:15:31.656033 [ 48606 ] {3988efd7-52fe-4c30-969a-fff43e1722c8} TCPHandler: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT CAST(now64(), 'IntervalSecond'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018577d95 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001856e84f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 16. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 18. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:15:31.657841 [ 48606 ] {0a9d8643-6619-40a3-aa9f-9549d44edd1a} executeQuery: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT toIntervalSecond(now64()). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:57940) (comment: 01291_unsupported_conversion_from_decimal.sql) (in query: SELECT toIntervalSecond(now64());), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018577d95 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001856e84f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:31.657979 [ 48606 ] {0a9d8643-6619-40a3-aa9f-9549d44edd1a} TCPHandler: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT toIntervalSecond(now64()). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018577d95 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001856e84f 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:31.660057 [ 48606 ] {32784a60-dbec-4553-9414-81f38d0c63b1} executeQuery: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT CAST(now64(), 'IntervalSecond'). (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:57940) (comment: 01291_unsupported_conversion_from_decimal.sql) (in query: SELECT CAST(now64() AS IntervalSecond);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018577d95 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001856e84f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 16. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 18. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:15:31.660242 [ 48606 ] {32784a60-dbec-4553-9414-81f38d0c63b1} TCPHandler: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT CAST(now64(), 'IntervalSecond'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000018577d95 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001856e84f 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000180936ae 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000018295efb 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001824f7cb 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 16. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 18. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 20. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 23. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 24. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 29. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 31. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 2025.03.05 21:15:31.940405 [ 48606 ] {7b28ebc9-e2f7-47d5-b553-abc89a5ee5a4} executeQuery: Code: 469. DB::Exception: Constraint `c` for table test_gilky9wo.default_constraints (217d479b-ef83-4a04-98e4-dd662b88b2e6) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:58022) (comment: 01286_constraints_on_default.sql) (in query: INSERT INTO default_constraints (x) SELECT number FROM system.numbers LIMIT 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:31.940624 [ 48606 ] {7b28ebc9-e2f7-47d5-b553-abc89a5ee5a4} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table test_gilky9wo.default_constraints (217d479b-ef83-4a04-98e4-dd662b88b2e6) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:31.944507 [ 48606 ] {b8a23aff-7b51-4c71-bb19-869cace55039} executeQuery: Code: 469. DB::Exception: Constraint `c` for table test_gilky9wo.default_constraints (217d479b-ef83-4a04-98e4-dd662b88b2e6) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:58022) (comment: 01286_constraints_on_default.sql) (in query: INSERT INTO default_constraints (x) VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:31.944591 [ 48606 ] {b8a23aff-7b51-4c71-bb19-869cace55039} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table test_gilky9wo.default_constraints (217d479b-ef83-4a04-98e4-dd662b88b2e6) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:31.981231 [ 48606 ] {f3b92ad1-9fb1-41bb-8861-471e47099024} executeQuery: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_078b758e-f52f-4c20-a301-6526c54759fd` (078b758e-f52f-4c20-a301-6526c54759fd) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:58022) (comment: 01286_constraints_on_default.sql) (in query: INSERT INTO default_constraints (x) SELECT number FROM system.numbers LIMIT 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:31.981377 [ 48606 ] {f3b92ad1-9fb1-41bb-8861-471e47099024} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_078b758e-f52f-4c20-a301-6526c54759fd` (078b758e-f52f-4c20-a301-6526c54759fd) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:31.984196 [ 48606 ] {14201ee1-e1c4-4733-b0dd-40d855e5d4c2} executeQuery: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_078b758e-f52f-4c20-a301-6526c54759fd` (078b758e-f52f-4c20-a301-6526c54759fd) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:58022) (comment: 01286_constraints_on_default.sql) (in query: INSERT INTO default_constraints (x) VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:31.984293 [ 48606 ] {14201ee1-e1c4-4733-b0dd-40d855e5d4c2} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_078b758e-f52f-4c20-a301-6526c54759fd` (078b758e-f52f-4c20-a301-6526c54759fd) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:32.455938 [ 1574 ] {e9c94200-ca6a-4d32-9132-d479767e0fce} executeQuery: Code: 43. DB::Exception: Second argument of function fuzzBits must be constant float: In scope SELECT fuzzBits(toString('string'), 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58134) (comment: 01284_fuzz_bits.sql) (in query: SELECT fuzzBits(toString('string'), 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionFuzzBits::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b98be5d 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:32.456089 [ 1574 ] {e9c94200-ca6a-4d32-9132-d479767e0fce} TCPHandler: Code: 43. DB::Exception: Second argument of function fuzzBits must be constant float: In scope SELECT fuzzBits(toString('string'), 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionFuzzBits::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b98be5d 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:32.483213 [ 1574 ] {59271b6a-4509-4c9b-a0d2-5ffcce170d70} executeQuery: Code: 69. DB::Exception: Second argument of function fuzzBits must be from `0.0` to `1.0`: In scope SELECT fuzzBits('string', -1.). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:58134) (comment: 01284_fuzz_bits.sql) (in query: SELECT fuzzBits('string', -1.0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionFuzzBits::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b98b168 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:32.483409 [ 1574 ] {59271b6a-4509-4c9b-a0d2-5ffcce170d70} TCPHandler: Code: 69. DB::Exception: Second argument of function fuzzBits must be from `0.0` to `1.0`: In scope SELECT fuzzBits('string', -1.). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionFuzzBits::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b98b168 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:32.663611 [ 5338 ] {9eace5ae-78ba-49f7-bb7b-9b3279370c30} executeQuery: Code: 48. DB::Exception: Cannot rename and modify the same column `value1_string` in a single ALTER query. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:58174) (comment: 01281_alter_rename_and_other_renames.sql) (in query: ALTER TABLE rename_table_multiple RENAME COLUMN value1 TO value1_string, MODIFY COLUMN value1_string String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a25b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:32.663772 [ 5338 ] {9eace5ae-78ba-49f7-bb7b-9b3279370c30} TCPHandler: Code: 48. DB::Exception: Cannot rename and modify the same column `value1_string` in a single ALTER query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a25b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:32.683506 [ 5338 ] {ca00e639-e6f2-4acc-a111-495985bd2134} executeQuery: Code: 48. DB::Exception: Cannot rename and modify the same column `value1` in a single ALTER query. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:58174) (comment: 01281_alter_rename_and_other_renames.sql) (in query: ALTER TABLE rename_table_multiple MODIFY COLUMN value1 String, RENAME COLUMN value1 to value1_string;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a8db 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:32.683719 [ 5338 ] {ca00e639-e6f2-4acc-a111-495985bd2134} TCPHandler: Code: 48. DB::Exception: Cannot rename and modify the same column `value1` in a single ALTER query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a8db 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:32.783484 [ 5338 ] {dc646aa3-dfea-4163-9b17-73f86f1972f8} executeQuery: Code: 48. DB::Exception: Cannot rename and modify the same column `value1_string` in a single ALTER query. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:58174) (comment: 01281_alter_rename_and_other_renames.sql) (in query: ALTER TABLE rename_table_multiple_compact RENAME COLUMN value1 TO value1_string, MODIFY COLUMN value1_string String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a25b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:32.783644 [ 5338 ] {dc646aa3-dfea-4163-9b17-73f86f1972f8} TCPHandler: Code: 48. DB::Exception: Cannot rename and modify the same column `value1_string` in a single ALTER query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a25b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:32.784953 [ 5338 ] {eb5cbc5d-8827-4c56-8d6b-1f27a0cc14f0} executeQuery: Code: 48. DB::Exception: Cannot rename and modify the same column `value1` in a single ALTER query. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:58174) (comment: 01281_alter_rename_and_other_renames.sql) (in query: ALTER TABLE rename_table_multiple_compact MODIFY COLUMN value1 String, RENAME COLUMN value1 to value1_string;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a8db 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:32.785084 [ 5338 ] {eb5cbc5d-8827-4c56-8d6b-1f27a0cc14f0} TCPHandler: Code: 48. DB::Exception: Cannot rename and modify the same column `value1` in a single ALTER query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a8db 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.080213 [ 48606 ] {6a141ef1-d9a2-4fb6-a007-5fdcd9fb283a} executeQuery: Code: 43. DB::Exception: First argument of function randomStringUTF8 must have numeric type: In scope SELECT randomStringUTF8('string'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58266) (comment: 01278_random_string_utf8.sql) (in query: SELECT randomStringUTF8('string');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionRandomStringUTF8::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000213b2aee 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.080387 [ 48606 ] {6a141ef1-d9a2-4fb6-a007-5fdcd9fb283a} TCPHandler: Code: 43. DB::Exception: First argument of function randomStringUTF8 must have numeric type: In scope SELECT randomStringUTF8('string'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionRandomStringUTF8::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000213b2aee 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.201202 [ 48606 ] {22958cfa-a98c-46fb-aaf3-bee91abdfb51} executeQuery: Code: 43. DB::Exception: First argument for function randomFixedString must be unsigned integer: In scope SELECT randomFixedString('string'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58296) (comment: 01277_random_fixed_string.sql) (in query: SELECT randomFixedString('string');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionRandomFixedStringImpl::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213a97c1 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.201430 [ 48606 ] {22958cfa-a98c-46fb-aaf3-bee91abdfb51} TCPHandler: Code: 43. DB::Exception: First argument for function randomFixedString must be unsigned integer: In scope SELECT randomFixedString('string'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionRandomFixedStringImpl::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213a97c1 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.246474 [ 48606 ] {82b4569c-9303-4634-a160-76f9dc414157} executeQuery: Code: 69. DB::Exception: FixedString size must be positive: In scope SELECT randomFixedString(0). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:58296) (comment: 01277_random_fixed_string.sql) (in query: SELECT randomFixedString(0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::DataTypeFixedString::DataTypeFixedString(unsigned long) @ 0x00000000181e288d 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned long const&) @ 0x000000001821001f 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned long const&, void>(std::allocator const&, unsigned long const&) @ 0x000000001820fd80 7. DB::(anonymous namespace)::FunctionRandomFixedStringImpl::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213a95ea 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:33.246669 [ 48606 ] {82b4569c-9303-4634-a160-76f9dc414157} TCPHandler: Code: 69. DB::Exception: FixedString size must be positive: In scope SELECT randomFixedString(0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::DataTypeFixedString::DataTypeFixedString(unsigned long) @ 0x00000000181e288d 5. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000](std::allocator, unsigned long const&) @ 0x000000001821001f 6. std::shared_ptr std::allocate_shared[abi:v15000], unsigned long const&, void>(std::allocator const&, unsigned long const&) @ 0x000000001820fd80 7. DB::(anonymous namespace)::FunctionRandomFixedStringImpl::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213a95ea 8. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 9. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 10. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:33.271179 [ 48606 ] {8f0b42ee-905c-404c-ae14-bf013a4d71c1} executeQuery: Code: 44. DB::Exception: First argument for function randomFixedString must be constant: In scope SELECT randomFixedString(rand() % 10). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:58296) (comment: 01277_random_fixed_string.sql) (in query: SELECT randomFixedString(rand() % 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionRandomFixedStringImpl::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213a96dd 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.271389 [ 48606 ] {8f0b42ee-905c-404c-ae14-bf013a4d71c1} TCPHandler: Code: 44. DB::Exception: First argument for function randomFixedString must be constant: In scope SELECT randomFixedString(rand() % 10). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionRandomFixedStringImpl::getReturnTypeImpl(std::vector> const&) const @ 0x00000000213a96dd 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.350316 [ 22866 ] {fdb9bba5-550a-4b11-b0d4-cddb04b53963} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:58314) (comment: 01277_toUnixTimestamp64.sql) (in query: -- Error cases SELECT toUnixTimestamp64Milli();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.350449 [ 22866 ] {fdb9bba5-550a-4b11-b0d4-cddb04b53963} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.352046 [ 22866 ] {b85579e2-0fb1-41c8-9794-6e35c7a7d421} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:58314) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Micro();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.352188 [ 22866 ] {b85579e2-0fb1-41c8-9794-6e35c7a7d421} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.354371 [ 22866 ] {e6320347-4194-4434-8653-dbb415809715} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:58314) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Nano();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.354514 [ 22866 ] {e6320347-4194-4434-8653-dbb415809715} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.380502 [ 22866 ] {2a161712-5f45-4352-bc36-29b208c9bdc6} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'value' of function toUnixTimestamp64Milli, expected DateTime64, got String: In scope SELECT toUnixTimestamp64Milli('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58314) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Milli('abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021b1fc20 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.380731 [ 22866 ] {2a161712-5f45-4352-bc36-29b208c9bdc6} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'value' of function toUnixTimestamp64Milli, expected DateTime64, got String: In scope SELECT toUnixTimestamp64Milli('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021b1fc20 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.382685 [ 22866 ] {db15a936-696e-4756-8ade-5b9ff87936cb} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'value' of function toUnixTimestamp64Micro, expected DateTime64, got String: In scope SELECT toUnixTimestamp64Micro('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58314) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Micro('abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021b1fc20 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.382824 [ 22866 ] {db15a936-696e-4756-8ade-5b9ff87936cb} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'value' of function toUnixTimestamp64Micro, expected DateTime64, got String: In scope SELECT toUnixTimestamp64Micro('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021b1fc20 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.384089 [ 22866 ] {37ab6a5d-1d05-470d-81c7-e24b6faa2633} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'value' of function toUnixTimestamp64Nano, expected DateTime64, got String: In scope SELECT toUnixTimestamp64Nano('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58314) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Nano('abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021b1fc20 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.384225 [ 22866 ] {37ab6a5d-1d05-470d-81c7-e24b6faa2633} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'value' of function toUnixTimestamp64Nano, expected DateTime64, got String: In scope SELECT toUnixTimestamp64Nano('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021b1fc20 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.385863 [ 22866 ] {b267a043-df48-413b-9c83-2d7a6fc396d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:58314) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Milli('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.385997 [ 22866 ] {b267a043-df48-413b-9c83-2d7a6fc396d8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.387361 [ 22866 ] {5c385621-2108-40d8-8fb5-9c790f39f3a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:58314) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Micro('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.387515 [ 22866 ] {5c385621-2108-40d8-8fb5-9c790f39f3a6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.388771 [ 22866 ] {45a68147-d31d-403e-9219-7ca80bb56368} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:58314) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Nano('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.388875 [ 22866 ] {45a68147-d31d-403e-9219-7ca80bb56368} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.800688 [ 22866 ] {5b203202-2947-4566-81ac-47741a1009b1} executeQuery: Code: 469. DB::Exception: Constraint `cs_value2` for table test_lmdv8tl0.table_for_rename1 (b0561eb1-6eba-4450-9823-d15733a49a6e) is violated at row 1. Expression: (toInt64(value2) < toInt64(value3)). Column values: value2 = '1', value3 = '0'. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:58346) (comment: 01277_alter_rename_column_constraint_zookeeper_long.sql) (in query: INSERT INTO table_for_rename1 SELECT toDate('2019-10-01') + number % 3, number, toString(number), toString(number + 1), toString(number) from numbers(9);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.800903 [ 22866 ] {5b203202-2947-4566-81ac-47741a1009b1} TCPHandler: Code: 469. DB::Exception: Constraint `cs_value2` for table test_lmdv8tl0.table_for_rename1 (b0561eb1-6eba-4450-9823-d15733a49a6e) is violated at row 1. Expression: (toInt64(value2) < toInt64(value3)). Column values: value2 = '1', value3 = '0'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.952257 [ 22866 ] {ecdf62c5-de5b-4e54-9e3b-44856f0a256a} executeQuery: Code: 469. DB::Exception: Constraint `cs_value2` for table test_lmdv8tl0.table_for_rename1 (b0561eb1-6eba-4450-9823-d15733a49a6e) is violated at row 1. Expression: (toInt64(value5) < toInt64(value3)). Column values: value5 = '11', value3 = '10'. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:58346) (comment: 01277_alter_rename_column_constraint_zookeeper_long.sql) (in query: INSERT INTO table_for_rename1 SELECT toDate('2019-10-01') + number % 3, number, toString(number), toString(number + 1), toString(number) from numbers(10, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:33.952456 [ 22866 ] {ecdf62c5-de5b-4e54-9e3b-44856f0a256a} TCPHandler: Code: 469. DB::Exception: Constraint `cs_value2` for table test_lmdv8tl0.table_for_rename1 (b0561eb1-6eba-4450-9823-d15733a49a6e) is violated at row 1. Expression: (toInt64(value5) < toInt64(value3)). Column values: value5 = '11', value3 = '10'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.058731 [ 23639 ] {19b34312-13d2-4f6d-8d4e-894aab611982} executeQuery: Code: 469. DB::Exception: Constraint `cs_value2` for table test_920ulyk8.table_for_rename (58ca2508-3d70-446c-8116-a847a979c59b) is violated at row 1. Expression: (toInt64(value2) < toInt64(value3)). Column values: value2 = '1', value3 = '0'. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:58386) (comment: 01277_alter_rename_column_constraint.sql) (in query: INSERT INTO table_for_rename SELECT toDate('2019-10-01') + number % 3, number, toString(number), toString(number + 1), toString(number) from numbers(9);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.058973 [ 23639 ] {19b34312-13d2-4f6d-8d4e-894aab611982} TCPHandler: Code: 469. DB::Exception: Constraint `cs_value2` for table test_920ulyk8.table_for_rename (58ca2508-3d70-446c-8116-a847a979c59b) is violated at row 1. Expression: (toInt64(value2) < toInt64(value3)). Column values: value2 = '1', value3 = '0'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.240042 [ 22866 ] {92450888-129f-4956-adf9-96682ff85a18} executeQuery: Code: 469. DB::Exception: Constraint `cs_value1` for table test_lmdv8tl0.table_for_rename1 (b0561eb1-6eba-4450-9823-d15733a49a6e) is violated at row 1. Expression: (toInt64(value1) < toInt64(value2)). Column values: value1 = '20', value2 = '20'. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:58346) (comment: 01277_alter_rename_column_constraint_zookeeper_long.sql) (in query: INSERT INTO table_for_rename1 SELECT toDate('2019-10-01') + number % 3, number, toString(number), toString(number), toString(number + 2) from numbers(20, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.240277 [ 22866 ] {92450888-129f-4956-adf9-96682ff85a18} TCPHandler: Code: 469. DB::Exception: Constraint `cs_value1` for table test_lmdv8tl0.table_for_rename1 (b0561eb1-6eba-4450-9823-d15733a49a6e) is violated at row 1. Expression: (toInt64(value1) < toInt64(value2)). Column values: value1 = '20', value2 = '20'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.303274 [ 23639 ] {efa922a8-b5f6-4cc0-9358-ad2f8ab311b1} executeQuery: Code: 469. DB::Exception: Constraint `cs_value2` for table test_920ulyk8.table_for_rename (58ca2508-3d70-446c-8116-a847a979c59b) is violated at row 1. Expression: (toInt64(value5) < toInt64(value3)). Column values: value5 = '11', value3 = '10'. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:58386) (comment: 01277_alter_rename_column_constraint.sql) (in query: INSERT INTO table_for_rename SELECT toDate('2019-10-01') + number % 3, number, toString(number), toString(number + 1), toString(number) from numbers(10, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.303517 [ 23639 ] {efa922a8-b5f6-4cc0-9358-ad2f8ab311b1} TCPHandler: Code: 469. DB::Exception: Constraint `cs_value2` for table test_920ulyk8.table_for_rename (58ca2508-3d70-446c-8116-a847a979c59b) is violated at row 1. Expression: (toInt64(value5) < toInt64(value3)). Column values: value5 = '11', value3 = '10'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.498156 [ 23639 ] {9e044c22-e356-41ae-8f4e-29d931209c0b} executeQuery: Code: 469. DB::Exception: Constraint `cs_value1` for table test_920ulyk8.table_for_rename (58ca2508-3d70-446c-8116-a847a979c59b) is violated at row 1. Expression: (toInt64(value1) < toInt64(value2)). Column values: value1 = '20', value2 = '20'. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:58386) (comment: 01277_alter_rename_column_constraint.sql) (in query: INSERT INTO table_for_rename SELECT toDate('2019-10-01') + number % 3, number, toString(number), toString(number), toString(number + 2) from numbers(20, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.498353 [ 23639 ] {9e044c22-e356-41ae-8f4e-29d931209c0b} TCPHandler: Code: 469. DB::Exception: Constraint `cs_value1` for table test_920ulyk8.table_for_rename (58ca2508-3d70-446c-8116-a847a979c59b) is violated at row 1. Expression: (toInt64(value1) < toInt64(value2)). Column values: value1 = '20', value2 = '20'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.575478 [ 23610 ] {ae7d46c9-8f79-42ab-a301-29d43568a882} executeQuery: Code: 53. DB::Exception: Cannot convert string qEkek.. to type IntervalMinute. (TYPE_MISMATCH) (version 24.3.12.76.altinitystable) (from [::1]:58474) (comment: 01277_convert_field_to_type_logical_error.sql) (in query: SELECT -2487, globalNullIn(toIntervalMinute(-88074), 'qEkek..'), [-27.537293];), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169a592 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 6. ./src/Core/Field.h:450: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&) @ 0x000000003169aece 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::Block DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, bool) @ 0x0000000030946c64 8. ./contrib/llvm-project/libcxx/include/vector:1318: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000030944898 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1911 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.575705 [ 23610 ] {ae7d46c9-8f79-42ab-a301-29d43568a882} TCPHandler: Code: 53. DB::Exception: Cannot convert string qEkek.. to type IntervalMinute. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169a592 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 6. ./src/Core/Field.h:450: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&) @ 0x000000003169aece 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::Block DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, bool) @ 0x0000000030946c64 8. ./contrib/llvm-project/libcxx/include/vector:1318: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000030944898 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1911 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.826853 [ 23639 ] {6fc51e3c-3fc7-4bfd-a176-ff2d3e40e438} executeQuery: Code: 36. DB::Exception: extractGroups length of 'needle' argument must be greater than 0.: In scope SELECT extractGroups('hello', ''). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:58522) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractGroups('hello', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86b4a7 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.827092 [ 23639 ] {6fc51e3c-3fc7-4bfd-a176-ff2d3e40e438} TCPHandler: Code: 36. DB::Exception: extractGroups length of 'needle' argument must be greater than 0.: In scope SELECT extractGroups('hello', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86b4a7 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.860620 [ 23639 ] {bbe64dca-61a3-400b-a4d0-02701d99c971} executeQuery: Code: 36. DB::Exception: Length of 'needle' argument must be greater than 0.: In scope SELECT extractAllGroups('hello', ''). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:58522) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractAllGroups('hello', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b869465 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:34.860627 [ 23610 ] {5b20b669-4954-4469-9e3b-34cea16a357b} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 0, should be 2: In scope SELECT extractGroups(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:58528) (comment: 01273_extractGroups.sql) (in query: -- error cases SELECT extractGroups();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.860864 [ 23639 ] {bbe64dca-61a3-400b-a4d0-02701d99c971} TCPHandler: Code: 36. DB::Exception: Length of 'needle' argument must be greater than 0.: In scope SELECT extractAllGroups('hello', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b869465 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:34.860884 [ 23610 ] {5b20b669-4954-4469-9e3b-34cea16a357b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 0, should be 2: In scope SELECT extractGroups(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.862652 [ 23610 ] {83822197-8d83-4df7-8d51-2e56f6942884} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 1, should be 2: In scope SELECT extractGroups('hello'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:58528) (comment: 01273_extractGroups.sql) (in query: SELECT extractGroups('hello');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.862778 [ 23610 ] {83822197-8d83-4df7-8d51-2e56f6942884} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 1, should be 2: In scope SELECT extractGroups('hello'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.890085 [ 23639 ] {26dcee86-a9db-4bc2-a116-406686f5ade8} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractGroups('hello', ' '). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:58522) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractGroups('hello', ' ');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86b541 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.925524 [ 23610 ] {3290c907-9281-47e0-856e-2f97d71aa0fd} executeQuery: Code: 43. DB::Exception: Illegal type of argument #2 'needle' of function extractGroups, expected const String or const FixedString, got UInt8: In scope SELECT extractGroups('hello', 123). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58528) (comment: 01273_extractGroups.sql) (in query: SELECT extractGroups('hello', 123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionExtractGroups::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b86b9c3 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.925599 [ 23639 ] {26dcee86-a9db-4bc2-a116-406686f5ade8} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractGroups('hello', ' '). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86b541 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.925904 [ 23610 ] {3290c907-9281-47e0-856e-2f97d71aa0fd} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #2 'needle' of function extractGroups, expected const String or const FixedString, got UInt8: In scope SELECT extractGroups('hello', 123). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionExtractGroups::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b86b9c3 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.928911 [ 23610 ] {b325d4b8-4cee-4a0a-8d35-f5aa4c0bff36} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'haystack' of function extractGroups, expected const String or const FixedString, got UInt8: In scope SELECT extractGroups(123, 'world'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58528) (comment: 01273_extractGroups.sql) (in query: SELECT extractGroups(123, 'world');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionExtractGroups::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b86b9c3 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.929199 [ 23610 ] {b325d4b8-4cee-4a0a-8d35-f5aa4c0bff36} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'haystack' of function extractGroups, expected const String or const FixedString, got UInt8: In scope SELECT extractGroups(123, 'world'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionExtractGroups::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b86b9c3 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.961219 [ 23639 ] {ba8e179f-fa9a-4c05-a241-38b0541f1e5a} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractAllGroups('hello', ' '). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:58522) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractAllGroups('hello', ' ');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b869504 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:34.961442 [ 23639 ] {ba8e179f-fa9a-4c05-a241-38b0541f1e5a} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractAllGroups('hello', ' '). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b869504 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:34.989149 [ 23610 ] {e58bfcc2-3f0c-4fcf-acbd-9ce50202ecce} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: (((, error: missing ): (((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT extractGroups('hello world', '((('). (CANNOT_COMPILE_REGEXP) (version 24.3.12.76.altinitystable) (from [::1]:58528) (comment: 01273_extractGroups.sql) (in query: SELECT extractGroups('hello world', '(((');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x00000000246a44f4 5. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86ad46 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:34.989160 [ 23639 ] {9ea4d556-4313-412d-aca8-38d0356b1097} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractGroups('hello', '\0'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:58522) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractGroups('hello', '\0');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86b541 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.996550 [ 23610 ] {e58bfcc2-3f0c-4fcf-acbd-9ce50202ecce} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: (((, error: missing ): (((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT extractGroups('hello world', '((('). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x00000000246a44f4 5. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86ad46 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:34.996691 [ 23639 ] {9ea4d556-4313-412d-aca8-38d0356b1097} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractGroups('hello', '\0'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86b541 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.999104 [ 23610 ] {7b0e75ce-5582-4232-b483-a46d5a8405da} executeQuery: Code: 44. DB::Exception: Illegal type of argument #2 'needle' of function extractGroups, expected const String or const FixedString, got String: In scope SELECT extractGroups('hello world', materialize('\\w+')). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:58528) (comment: 01273_extractGroups.sql) (in query: SELECT extractGroups('hello world', materialize('\\w+'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionExtractGroups::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b86b9c3 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:34.999287 [ 23610 ] {7b0e75ce-5582-4232-b483-a46d5a8405da} TCPHandler: Code: 44. DB::Exception: Illegal type of argument #2 'needle' of function extractGroups, expected const String or const FixedString, got String: In scope SELECT extractGroups('hello world', materialize('\\w+')). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::(anonymous namespace)::FunctionExtractGroups::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b86b9c3 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.001841 [ 23639 ] {1260ecbf-a02c-499d-9a78-949a35591d6f} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractAllGroups('hello', '\0'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:58522) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractAllGroups('hello', '\0');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b869504 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:35.002008 [ 23639 ] {1260ecbf-a02c-499d-9a78-949a35591d6f} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractAllGroups('hello', '\0'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b869504 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:35.004760 [ 23639 ] {cda4c61f-9903-4a9c-bb1d-827dd8c5b9c6} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: world: In scope SELECT extractGroups('hello', 'world'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:58522) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractGroups('hello', 'world');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86b541 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.005001 [ 23639 ] {cda4c61f-9903-4a9c-bb1d-827dd8c5b9c6} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: world: In scope SELECT extractGroups('hello', 'world'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86b541 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.007098 [ 23639 ] {7c796192-d4c5-4eaf-937e-3d74417f3820} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: world: In scope SELECT extractAllGroups('hello', 'world'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:58522) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractAllGroups('hello', 'world');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b869504 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:35.007228 [ 23639 ] {7c796192-d4c5-4eaf-937e-3d74417f3820} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: world: In scope SELECT extractAllGroups('hello', 'world'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b869504 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:35.037423 [ 23639 ] {1c9db15f-191c-41f8-8501-e336b640cf39} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: hello|world: In scope SELECT extractGroups('hello', 'hello|world'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:58522) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractGroups('hello', 'hello|world');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86b5e1 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.037438 [ 23610 ] {93bcf377-d67b-4964-9708-6f6247795dac} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: \w+: In scope SELECT extractGroups('hello world', '\\w+'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:58528) (comment: 01273_extractGroups.sql) (in query: SELECT extractGroups('hello world', '\\w+');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86b5e1 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.037645 [ 23639 ] {1c9db15f-191c-41f8-8501-e336b640cf39} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: hello|world: In scope SELECT extractGroups('hello', 'hello|world'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86b5e1 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.037655 [ 23610 ] {93bcf377-d67b-4964-9708-6f6247795dac} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: \w+: In scope SELECT extractGroups('hello world', '\\w+'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86b5e1 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.069762 [ 23639 ] {360d9f62-c1d1-4008-992e-ee79dc9e4c22} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: hello|world: In scope SELECT extractAllGroups('hello', 'hello|world'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:58522) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractAllGroups('hello', 'hello|world');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8695a7 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:35.070043 [ 23639 ] {360d9f62-c1d1-4008-992e-ee79dc9e4c22} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: hello|world: In scope SELECT extractAllGroups('hello', 'hello|world'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8695a7 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:35.328540 [ 23622 ] {c20ab151-b3cb-4528-8480-596d5c5dd1d4} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function toStartOfSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfSecond('123'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58640) (comment: 01269_toStartOfSecond.sql) (in query: -- Error cases SELECT toStartOfSecond('123');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x0000000021af5f0b 5. DB::FunctionDateOrDateTimeToSomething::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021af2e97 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.328849 [ 23622 ] {c20ab151-b3cb-4528-8480-596d5c5dd1d4} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function toStartOfSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfSecond('123'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x0000000021af5f0b 5. DB::FunctionDateOrDateTimeToSomething::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021af2e97 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.358630 [ 23622 ] {dc6d5b5c-b6d5-4e63-8d4b-31f8f66ca2ec} executeQuery: Code: 43. DB::Exception: Illegal type DateTime of argument for function toStartOfSecond: In scope SELECT toStartOfSecond(now()). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58640) (comment: 01269_toStartOfSecond.sql) (in query: SELECT toStartOfSecond(now());), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. void DB::Transformer::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToStartOfSecondImpl const&, DB::PODArray, 63ul, 64ul>*) @ 0x0000000021af5ace 5. COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfSecondImpl const&) @ 0x0000000021af49b7 6. DB::FunctionDateOrDateTimeToSomething::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021af2748 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:15:35.358861 [ 23622 ] {dc6d5b5c-b6d5-4e63-8d4b-31f8f66ca2ec} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime of argument for function toStartOfSecond: In scope SELECT toStartOfSecond(now()). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x00000000181d15db 4. void DB::Transformer::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToStartOfSecondImpl const&, DB::PODArray, 63ul, 64ul>*) @ 0x0000000021af5ace 5. COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfSecondImpl const&) @ 0x0000000021af49b7 6. DB::FunctionDateOrDateTimeToSomething::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000021af2748 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:15:35.385155 [ 23622 ] {2c99af0e-3550-4a9a-822d-fec59b443e17} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:58640) (comment: 01269_toStartOfSecond.sql) (in query: SELECT toStartOfSecond();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000001806a053 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x0000000021af60ca 5. DB::FunctionDateOrDateTimeToSomething::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021af2e97 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.385350 [ 23622 ] {2c99af0e-3550-4a9a-822d-fec59b443e17} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000001806a053 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x0000000021af60ca 5. DB::FunctionDateOrDateTimeToSomething::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021af2e97 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.411446 [ 23622 ] {e6962038-d272-47b0-be2d-b918d787237d} executeQuery: Code: 43. DB::Exception: Function toStartOfSecond supports 1 or 2 arguments. The optional 2nd argument must be a constant string with a timezone name: In scope SELECT toStartOfSecond(now64(), 123). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58640) (comment: 01269_toStartOfSecond.sql) (in query: SELECT toStartOfSecond(now64(), 123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x0000000021af6358 5. DB::FunctionDateOrDateTimeToSomething::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021af2e97 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.411649 [ 23622 ] {e6962038-d272-47b0-be2d-b918d787237d} TCPHandler: Code: 43. DB::Exception: Function toStartOfSecond supports 1 or 2 arguments. The optional 2nd argument must be a constant string with a timezone name: In scope SELECT toStartOfSecond(now64(), 123). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x0000000021af6358 5. DB::FunctionDateOrDateTimeToSomething::getReturnTypeImpl(std::vector> const&) const @ 0x0000000021af2e97 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.689975 [ 64953 ] {1ce98e62-05e6-4285-b00c-3be503636612} executeQuery: Code: 43. DB::Exception: No operation equals between DateTime64(3) and String. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58706) (comment: 01268_DateTime64_in_WHERE.sql) (in query: -- Error cases: -- non-const string column WITH '2020-02-05 14:34:12.333' as S, toDateTime64(S, 3) as DT64 SELECT DT64 = materialize(S);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1843d5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.690241 [ 64953 ] {1ce98e62-05e6-4285-b00c-3be503636612} TCPHandler: Code: 43. DB::Exception: No operation equals between DateTime64(3) and String. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1843d5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.694207 [ 64953 ] {078da883-2b06-404d-b6b0-907721e36296} executeQuery: Code: 43. DB::Exception: No operation equals between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58706) (comment: 01268_DateTime64_in_WHERE.sql) (in query: WITH '2020-02-05 14:34:12.333' as S, toDateTime64(S, 3) as DT64 SELECT materialize(S) = toDateTime64(S, 3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1843d5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.694405 [ 64953 ] {078da883-2b06-404d-b6b0-907721e36296} TCPHandler: Code: 43. DB::Exception: No operation equals between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1843d5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.726880 [ 64953 ] {2b206b8e-2cde-4b36-85f8-64befef49d45} executeQuery: Code: 43. DB::Exception: No operation equals between DateTime64(3) and String. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58706) (comment: 01268_DateTime64_in_WHERE.sql) (in query: WITH '2020-02-05 14:34:12.333' as S, toDateTime64(S, 3) as DT64 SELECT * WHERE DT64 = materialize(S);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1843d5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 14. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 15. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.727182 [ 64953 ] {2b206b8e-2cde-4b36-85f8-64befef49d45} TCPHandler: Code: 43. DB::Exception: No operation equals between DateTime64(3) and String. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1843d5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 14. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 15. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.731076 [ 64953 ] {436c762e-0da4-4fd4-a399-315da0d46528} executeQuery: Code: 43. DB::Exception: No operation equals between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:58706) (comment: 01268_DateTime64_in_WHERE.sql) (in query: WITH '2020-02-05 14:34:12.333' as S, toDateTime64(S, 3) as DT64 SELECT * WHERE materialize(S) = DT64;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1843d5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 14. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 15. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.731253 [ 64953 ] {436c762e-0da4-4fd4-a399-315da0d46528} TCPHandler: Code: 43. DB::Exception: No operation equals between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1843d5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::FilterTransform::transformHeader(DB::Block, DB::ActionsDAG const*, String const&, bool) @ 0x0000000033b579db 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, std::shared_ptr const&, String, bool) @ 0x0000000033ed4131 14. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15000] const&, String const&, bool const&>(DB::DataStream const&, std::shared_ptr const&, String const&, bool const&) @ 0x000000003102138d 15. ./build_docker/./src/Planner/Planner.cpp:347: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult const&, String const&, std::vector, std::allocator>>&) @ 0x0000000031018ef1 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003100d619 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:35.772358 [ 64953 ] {92f1bc30-701f-4896-bfea-80b9854ec3d8} executeQuery: Code: 41. DB::Exception: Cannot parse DateTime: while converting 'ABCD' to DateTime64(3): In scope SELECT * WHERE toDateTime64(123.345, 3) = 'ABCD'. (CANNOT_PARSE_DATETIME) (version 24.3.12.76.altinitystable) (from [::1]:58706) (comment: 01268_DateTime64_in_WHERE.sql) (in query: SELECT * WHERE toDateTime64(123.345, 3) == 'ABCD';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/ReadHelpers.cpp:0: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000247218a4 5. void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000187bf3d4 6. ./src/IO/ReadHelpers.h:0: DB::SerializationDateTime64::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5d51c1 7. ./build_docker/./src/DataTypes/Serializations/SerializationDateTime64.cpp:63: DB::SerializationDateTime64::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5d4f2a 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031699857 9. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 10. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1a2f0a 11. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1835c5 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:35.772706 [ 64953 ] {92f1bc30-701f-4896-bfea-80b9854ec3d8} TCPHandler: Code: 41. DB::Exception: Cannot parse DateTime: while converting 'ABCD' to DateTime64(3): In scope SELECT * WHERE toDateTime64(123.345, 3) = 'ABCD'. (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/IO/ReadHelpers.cpp:0: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000247218a4 5. void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000187bf3d4 6. ./src/IO/ReadHelpers.h:0: DB::SerializationDateTime64::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5d51c1 7. ./build_docker/./src/DataTypes/Serializations/SerializationDateTime64.cpp:63: DB::SerializationDateTime64::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5d4f2a 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031699857 9. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 10. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1a2f0a 11. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b1835c5 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086edc1 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 25. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 30. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 2025.03.05 21:15:36.327043 [ 48624 ] {0d05e196-71c1-46f2-9a9f-a24726fc93b3} executeQuery: Code: 36. DB::Exception: Unexpected value 2 in enum: while executing 'FUNCTION toString(__table1.v :: 0) -> toString(__table1.v) String : 1'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:58798) (comment: 01263_type_conversion_nvartolomei.sql) (in query: SELECT toString(v) FROM (SELECT v FROM d ORDER BY v) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001852ce5f 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018522093 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 20. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 21. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 22. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:36.327411 [ 48624 ] {0d05e196-71c1-46f2-9a9f-a24726fc93b3} TCPHandler: Code: 36. DB::Exception: Unexpected value 2 in enum: while executing 'FUNCTION toString(__table1.v :: 0) -> toString(__table1.v) String : 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018781378 5. DB::EnumValues<_BitInt(8)>::getNameForValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000018780ee4 6. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000001852ce5f 7. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018522093 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 20. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 21. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 22. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:36.415126 [ 48614 ] {c22c6650-f62d-4e5d-98ae-8db53810ef1d} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 101.60 MiB (attempt to allocate chunk of 2253150 bytes), maximum: 100.00 MiB.: while pushing to view test_lwyezpvg.mv_01278_3 (c5e4d6a6-6987-4994-85b7-42b619e75765). (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:58750) (comment: 01278_min_insert_block_size_rows_for_materialized_views.sh) (in query: insert into data_01278 select number, reinterpretAsString(number), // s1 reinterpretAsString(number), // s2 reinterpretAsString(number), // s3 reinterpretAsString(number), // s4 reinterpretAsString(number), // s5 reinterpretAsString(number), // s6 reinterpretAsString(number), // s7 reinterpretAsString(number) // s8 from numbers(200000); -- { serverError 241 }), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x00000000180629f4 9. ./src/Common/PODArray.h:0: void DB::filterArraysImpl(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul> const&, long) @ 0x0000000031fd4048 10. ./build_docker/./src/Columns/ColumnString.cpp:0: DB::ColumnString::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x0000000031b9e3a4 11. ./build_docker/./src/Columns/ColumnNullable.cpp:265: DB::ColumnNullable::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x0000000031b5d639 12. ./src/Columns/FilterDescription.h:45: DB::FilterDescription::filter(DB::IColumn const&, long) const @ 0x0000000031fdf226 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000033b5bf3f 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:265: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000033b598fa 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 19. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 21. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:753: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000033ca5936 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52c06 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51924 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 29. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 30. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 2025.03.05 21:15:36.419221 [ 48614 ] {c22c6650-f62d-4e5d-98ae-8db53810ef1d} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 101.60 MiB (attempt to allocate chunk of 2253150 bytes), maximum: 100.00 MiB.: while pushing to view test_lwyezpvg.mv_01278_3 (c5e4d6a6-6987-4994-85b7-42b619e75765). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x00000000180629f4 9. ./src/Common/PODArray.h:0: void DB::filterArraysImpl(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul> const&, long) @ 0x0000000031fd4048 10. ./build_docker/./src/Columns/ColumnString.cpp:0: DB::ColumnString::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x0000000031b9e3a4 11. ./build_docker/./src/Columns/ColumnNullable.cpp:265: DB::ColumnNullable::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x0000000031b5d639 12. ./src/Columns/FilterDescription.h:45: DB::FilterDescription::filter(DB::IColumn const&, long) const @ 0x0000000031fdf226 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000033b5bf3f 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:265: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000033b598fa 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 19. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 21. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:753: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000033ca5936 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52c06 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51924 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 29. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 30. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 2025.03.05 21:15:36.627287 [ 48624 ] {40547cb0-a553-49ba-94fa-c9c749f05aa0} executeQuery: Code: 70. DB::Exception: Conversion from AggregateFunction(argMax, String, UInt64) to AggregateFunction(argMax, Enum8('' = -1, 'Male' = 1, 'Female' = 2), UInt64) is not supported: While processing _CAST(arrayReduce('argMaxState', ['cast(-1, \'Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2)'], [toUInt64(0)]) AS t_tmp_alter1588813619497977870, 'AggregateFunction(argMax, Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2), UInt64)') AS t: default expression and column type are incompatible. (CANNOT_CONVERT_TYPE) (version 24.3.12.76.altinitystable) (from [::1]:58862) (comment: 01258_wrong_cast_filimonov.sql) (in query: CREATE TABLE x (`id` UInt64, `t` AggregateFunction(argMax, Enum8('' = -1, 'Male' = 1, 'Female' = 2), UInt64) DEFAULT arrayReduce('argMaxState', ['cast(-1, \'Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2)'], [toUInt64(0)])) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 46937, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 300983778, compact_parts_max_granules_to_buffer = 2, compact_parts_merge_max_bytes_to_prefetch_part = 5644272, merge_max_block_size = 14251, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 4717424267, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 28342181, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 54554, primary_key_compress_block_size = 33349), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000001825a92b 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e5b2 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002fb5db0b 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:244: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002fb5d0e3 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:645: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe2f05d 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe439bf 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe33cd5 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002fe1eecd 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, std::shared_ptr&, bool) @ 0x000000002fddf8d7 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002fdf74a8 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1787: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002fdf7af7 16. ./build_docker/./src/Storages/ColumnsDescription.cpp:948: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000320a6276 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b25b1 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:36.627516 [ 48624 ] {40547cb0-a553-49ba-94fa-c9c749f05aa0} TCPHandler: Code: 70. DB::Exception: Conversion from AggregateFunction(argMax, String, UInt64) to AggregateFunction(argMax, Enum8('' = -1, 'Male' = 1, 'Female' = 2), UInt64) is not supported: While processing _CAST(arrayReduce('argMaxState', ['cast(-1, \'Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2)'], [toUInt64(0)]) AS t_tmp_alter1588813619497977870, 'AggregateFunction(argMax, Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2), UInt64)') AS t: default expression and column type are incompatible. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000001825a92b 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001824e5b2 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x000000001824b6f8 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002fb5db0b 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:244: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002fb5d0e3 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:645: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe2f05d 10. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002fe439bf 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002fe33cd5 12. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002fe1eecd 13. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, std::shared_ptr&, bool) @ 0x000000002fddf8d7 14. ./contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002fdf74a8 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1787: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002fdf7af7 16. ./build_docker/./src/Storages/ColumnsDescription.cpp:948: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000320a6276 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, bool, bool) @ 0x00000000307b25b1 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:743: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b5302 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:36.689450 [ 48614 ] {35ed89a3-845d-44f5-8560-c3574360faa9} executeQuery: Code: 62. DB::Exception: Syntax error (columns declaration list): failed at position 3 (end of query): . Expected one of: NULL, NOT, DEFAULT, MATERIALIZED, EPHEMERAL, ALIAS, AUTO_INCREMENT, PRIMARY KEY, data type, nested table, identifier. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:58882) (comment: 01256_negative_generate_random.sql) (in query: SELECT * FROM generateRandom('i8', 1, 10, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQuery(DB::IParser&, String const&, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc3fd 6. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:118: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x000000003177558b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::TableFunctionGenerateRandom::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e48b744 8. ./contrib/llvm-project/libcxx/include/string:1570: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e48bfc1 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 10. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:36.689764 [ 48614 ] {35ed89a3-845d-44f5-8560-c3574360faa9} TCPHandler: Code: 62. DB::Exception: Syntax error (columns declaration list): failed at position 3 (end of query): . Expected one of: NULL, NOT, DEFAULT, MATERIALIZED, EPHEMERAL, ALIAS, AUTO_INCREMENT, PRIMARY KEY, data type, nested table, identifier. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQuery(DB::IParser&, String const&, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc3fd 6. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:118: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x000000003177558b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::TableFunctionGenerateRandom::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e48b744 8. ./contrib/llvm-project/libcxx/include/string:1570: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e48bfc1 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 10. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:36.692139 [ 48614 ] {a7ead94d-c90c-4f34-87ba-f66aae05db32} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'generateRandom' in scope SELECT * FROM generateRandom. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:58882) (comment: 01256_negative_generate_random.sql) (in query: SELECT * FROM generateRandom;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:36.692284 [ 48614 ] {a7ead94d-c90c-4f34-87ba-f66aae05db32} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'generateRandom' in scope SELECT * FROM generateRandom. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:36.715736 [ 48614 ] {f7e3b099-6290-49b4-a186-e7db25eacbb8} executeQuery: Code: 42. DB::Exception: Table function 'generateRandom' requires at most four (or three if structure is missing) arguments: [structure, random_seed, max_string_length, max_array_length]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:58882) (comment: 01256_negative_generate_random.sql) (in query: SELECT * FROM generateRandom('i8 UInt8', 1, 10, 10, 10, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:0: DB::(anonymous namespace)::TableFunctionGenerateRandom::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e48b149 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:36.715936 [ 48614 ] {f7e3b099-6290-49b4-a186-e7db25eacbb8} TCPHandler: Code: 42. DB::Exception: Table function 'generateRandom' requires at most four (or three if structure is missing) arguments: [structure, random_seed, max_string_length, max_array_length]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:0: DB::(anonymous namespace)::TableFunctionGenerateRandom::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e48b149 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x00000000308874bb 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:36.718131 [ 48614 ] {998376bd-1252-49f9-a139-aa23ccfeb251} executeQuery: Code: 62. DB::Exception: Empty query. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:58882) (comment: 01256_negative_generate_random.sql) (in query: SELECT * FROM generateRandom('', 1, 10, 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQuery(DB::IParser&, String const&, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc3fd 6. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:118: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x000000003177558b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::TableFunctionGenerateRandom::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e48b744 8. ./contrib/llvm-project/libcxx/include/string:1570: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e48bfc1 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 10. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:36.718255 [ 48614 ] {998376bd-1252-49f9-a139-aa23ccfeb251} TCPHandler: Code: 62. DB::Exception: Empty query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:398: DB::parseQuery(DB::IParser&, String const&, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc3fd 6. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:118: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x000000003177558b 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::TableFunctionGenerateRandom::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002e48b744 8. ./contrib/llvm-project/libcxx/include/string:1570: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e48bfc1 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 10. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:36.863735 [ 23553 ] {d6532818-175d-46b1-8d81-4f49b93ebccf} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 100.27 MiB (attempt to allocate chunk of 1089474 bytes), maximum: 100.00 MiB.: while pushing to view test_lwyezpvg.mv_01278_6 (420189c9-91c4-47c9-ab18-98f1cec5bd0e). (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:58874) (comment: 01278_min_insert_block_size_rows_for_materialized_views.sh) (in query: insert into data_01278 select number, reinterpretAsString(number), // s1 reinterpretAsString(number), // s2 reinterpretAsString(number), // s3 reinterpretAsString(number), // s4 reinterpretAsString(number), // s5 reinterpretAsString(number), // s6 reinterpretAsString(number), // s7 reinterpretAsString(number) // s8 from numbers(200000); -- { serverError 241 }), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000018067b94 9. ./src/Common/PODArray.h:0: void DB::filterArraysImpl(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul> const&, long) @ 0x0000000031fd40e2 10. ./build_docker/./src/Columns/ColumnString.cpp:0: DB::ColumnString::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x0000000031b9e3a4 11. ./build_docker/./src/Columns/ColumnNullable.cpp:265: DB::ColumnNullable::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x0000000031b5d639 12. ./src/Columns/FilterDescription.h:45: DB::FilterDescription::filter(DB::IColumn const&, long) const @ 0x0000000031fdf226 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000033b5bf3f 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:265: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000033b598fa 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 19. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 21. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:753: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000033ca5936 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52c06 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51924 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 29. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 30. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 2025.03.05 21:15:36.870259 [ 23553 ] {d6532818-175d-46b1-8d81-4f49b93ebccf} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 100.27 MiB (attempt to allocate chunk of 1089474 bytes), maximum: 100.00 MiB.: while pushing to view test_lwyezpvg.mv_01278_6 (420189c9-91c4-47c9-ab18-98f1cec5bd0e). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000002461ec21 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000018067b94 9. ./src/Common/PODArray.h:0: void DB::filterArraysImpl(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul> const&, long) @ 0x0000000031fd40e2 10. ./build_docker/./src/Columns/ColumnString.cpp:0: DB::ColumnString::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x0000000031b9e3a4 11. ./build_docker/./src/Columns/ColumnNullable.cpp:265: DB::ColumnNullable::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x0000000031b5d639 12. ./src/Columns/FilterDescription.h:45: DB::FilterDescription::filter(DB::IColumn const&, long) const @ 0x0000000031fdf226 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000033b5bf3f 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:265: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000033b598fa 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 19. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 21. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:753: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000033ca5936 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52c06 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b51924 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 29. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 30. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 2025.03.05 21:15:36.904127 [ 23642 ] {c7123f2f-2cd8-4a66-9580-bd335dd72fb2} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' at end of stream.: (at row 1) : Buffer has gone, cannot extract information about what has been parsed.: While executing TabSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:56822) (comment: 01271_http_code_parse_error.sh) (in query: insert into test (f1, f2) format TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./src/IO/ReadHelpers.h:203: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000033ab320d 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9817 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 9. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 15. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 18. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:36.904449 [ 23642 ] {c7123f2f-2cd8-4a66-9580-bd335dd72fb2} DynamicQueryHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' at end of stream.: (at row 1) : Buffer has gone, cannot extract information about what has been parsed.: While executing TabSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. ./build_docker/./src/IO/ReadHelpers.cpp:93: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000024706b77 5. ./src/IO/ReadHelpers.h:203: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000033ab320d 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x00000000336b9817 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000033663141 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 9. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 15. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000033556bc5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031703998 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 18. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:37.172285 [ 48598 ] {13766f77-e67d-4cd9-b476-15afef5a930c} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'ArrLen' in scope SELECT dummy AS x, plus(ignore(ignore(ignore(ignore('-922337203.6854775808', ignore(NULL)), ArrLen = 256, ignore(100, Arr.C3, ignore(NULL), (SELECT 10.000100135803223, count(*) FROM system.time_zones) > NULL)))), dummy, 65535) AS dummy ORDER BY ignore(-2) ASC, identity(x) DESC NULLS FIRST. (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:58990) (comment: 01247_some_msan_crashs_from_22517.sql) (in query: SELECT x FROM (SELECT dummy AS x, plus(ignore(ignore(ignore(ignore('-922337203.6854775808', ignore(NULL)), ArrLen = 256, ignore(100, Arr.C3, ignore(NULL), (SELECT 10.000100135803223, count(*) FROM system.time_zones) > NULL)))), dummy, 65535) AS dummy ORDER BY ignore(-2) ASC, identity(x) DESC NULLS FIRST) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 19. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 25. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6519: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882639 27. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7911: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd42 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 29. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 2025.03.05 21:15:37.172619 [ 48598 ] {13766f77-e67d-4cd9-b476-15afef5a930c} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'ArrLen' in scope SELECT dummy AS x, plus(ignore(ignore(ignore(ignore('-922337203.6854775808', ignore(NULL)), ArrLen = 256, ignore(100, Arr.C3, ignore(NULL), (SELECT 10.000100135803223, count(*) FROM system.time_zones) > NULL)))), dummy, 65535) AS dummy ORDER BY ignore(-2) ASC, identity(x) DESC NULLS FIRST. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 16. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 19. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 20. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089f05f 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089b52a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883738 23. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 25. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 26. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6519: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882639 27. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7911: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd42 28. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 29. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 2025.03.05 21:15:37.324294 [ 48598 ] {007b4c37-5f9b-4a7d-b9bb-d4deec5e8246} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsHorizontal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:59026) (comment: 01246_extractAllGroupsHorizontal.sql) (in query: -- error cases SELECT extractAllGroupsHorizontal();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:37.324437 [ 48598 ] {007b4c37-5f9b-4a7d-b9bb-d4deec5e8246} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsHorizontal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:37.326247 [ 48598 ] {47430804-868b-414e-9e37-7c9fb666bdd1} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 1, should be 2: In scope SELECT extractAllGroupsHorizontal('hello'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:59026) (comment: 01246_extractAllGroupsHorizontal.sql) (in query: SELECT extractAllGroupsHorizontal('hello');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:37.326370 [ 48598 ] {47430804-868b-414e-9e37-7c9fb666bdd1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 1, should be 2: In scope SELECT extractAllGroupsHorizontal('hello'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000029c08c5a 4. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002e843a8f 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e84432e 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:37.352444 [ 48598 ] {eeed07f5-ba7b-4a8b-95ea-a8fc048e20ee} executeQuery: Code: 43. DB::Exception: Illegal type of argument #2 'needle' of function extractAllGroupsHorizontal, expected const String or const FixedString, got UInt8: In scope SELECT extractAllGroupsHorizontal('hello', 123). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:59026) (comment: 01246_extractAllGroupsHorizontal.sql) (in query: SELECT extractAllGroupsHorizontal('hello', 123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b86619c 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:37.352770 [ 48598 ] {eeed07f5-ba7b-4a8b-95ea-a8fc048e20ee} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #2 'needle' of function extractAllGroupsHorizontal, expected const String or const FixedString, got UInt8: In scope SELECT extractAllGroupsHorizontal('hello', 123). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b86619c 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:37.355317 [ 48598 ] {b6970259-f45f-45b0-8f82-4b722c83c843} executeQuery: Code: 43. DB::Exception: Illegal type of argument #1 'haystack' of function extractAllGroupsHorizontal, expected const String or const FixedString, got UInt8: In scope SELECT extractAllGroupsHorizontal(123, 'world'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:59026) (comment: 01246_extractAllGroupsHorizontal.sql) (in query: SELECT extractAllGroupsHorizontal(123, 'world');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b86619c 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:37.355430 [ 48598 ] {b6970259-f45f-45b0-8f82-4b722c83c843} TCPHandler: Code: 43. DB::Exception: Illegal type of argument #1 'haystack' of function extractAllGroupsHorizontal, expected const String or const FixedString, got UInt8: In scope SELECT extractAllGroupsHorizontal(123, 'world'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b86619c 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:37.388527 [ 48598 ] {db68b96a-0d8a-45b2-b1f6-841f4ebb7ad1} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: (((, error: missing ): (((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT extractAllGroupsHorizontal('hello world', '((('). (CANNOT_COMPILE_REGEXP) (version 24.3.12.76.altinitystable) (from [::1]:59026) (comment: 01246_extractAllGroupsHorizontal.sql) (in query: SELECT extractAllGroupsHorizontal('hello world', '(((');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x00000000246a44f4 5. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8642b0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:37.388845 [ 48598 ] {db68b96a-0d8a-45b2-b1f6-841f4ebb7ad1} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: (((, error: missing ): (((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT extractAllGroupsHorizontal('hello world', '((('). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x00000000246a44f4 5. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b8642b0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 10. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 14. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 17. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 23. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 28. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 2025.03.05 21:15:37.392057 [ 48598 ] {bdcfb1fa-4324-4777-b403-e12926960759} executeQuery: Code: 44. DB::Exception: Illegal type of argument #2 'needle' of function extractAllGroupsHorizontal, expected const String or const FixedString, got String: In scope SELECT extractAllGroupsHorizontal('hello world', materialize('\\w+')). (ILLEGAL_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:59026) (comment: 01246_extractAllGroupsHorizontal.sql) (in query: SELECT extractAllGroupsHorizontal('hello world', materialize('\\w+'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b86619c 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:37.392270 [ 48598 ] {bdcfb1fa-4324-4777-b403-e12926960759} TCPHandler: Code: 44. DB::Exception: Illegal type of argument #2 'needle' of function extractAllGroupsHorizontal, expected const String or const FixedString, got String: In scope SELECT extractAllGroupsHorizontal('hello world', materialize('\\w+')). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&, String&&, String&&) @ 0x000000002e854e73 4. ./build_docker/./src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002e8526bf 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::validateFunctionArgumentTypes(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002e851435 6. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b86619c 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:37.437624 [ 48598 ] {8fba9077-cce9-4cae-b38a-3cb12e9bdc5c} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: \w+: In scope SELECT extractAllGroupsHorizontal('hello world', '\\w+'). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:59026) (comment: 01246_extractAllGroupsHorizontal.sql) (in query: SELECT extractAllGroupsHorizontal('hello world', '\\w+');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b865963 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:37.437917 [ 48598 ] {8fba9077-cce9-4cae-b38a-3cb12e9bdc5c} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: \w+: In scope SELECT extractAllGroupsHorizontal('hello world', '\\w+'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b865963 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:37.468946 [ 48598 ] {6623477c-a45a-4632-a0d3-ba7952f0ff2a} executeQuery: Code: 128. DB::Exception: Too many matches per row (> 0) in the result of function extractAllGroupsHorizontal: In scope SELECT extractAllGroupsHorizontal('hello world', '(\\w+)') SETTINGS regexp_max_matches_per_row = 0. (TOO_LARGE_ARRAY_SIZE) (version 24.3.12.76.altinitystable) (from [::1]:59026) (comment: 01246_extractAllGroupsHorizontal.sql) (in query: SELECT extractAllGroupsHorizontal('hello world', '(\\w+)') SETTINGS regexp_max_matches_per_row = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception const&, String>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, String&&) @ 0x000000001b8667f3 4. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86566d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:37.468954 [ 23611 ] {98e543ce-d937-4c1f-9026-cce5651b79b4} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt64 of arguments of function least: In scope SELECT LEAST(-1., 18446744073709551615). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:59028) (comment: 01246_least_greatest_generic.sql) (in query: -- This can be improved SELECT LEAST(-1., 18446744073709551615);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001dcb0d2f 5. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)0, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001d986e01 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:37.469143 [ 48598 ] {6623477c-a45a-4632-a0d3-ba7952f0ff2a} TCPHandler: Code: 128. DB::Exception: Too many matches per row (> 0) in the result of function extractAllGroupsHorizontal: In scope SELECT extractAllGroupsHorizontal('hello world', '(\\w+)') SETTINGS regexp_max_matches_per_row = 0. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception const&, String>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, String&&) @ 0x000000001b8667f3 4. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86566d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:37.469216 [ 23611 ] {98e543ce-d937-4c1f-9026-cce5651b79b4} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt64 of arguments of function least: In scope SELECT LEAST(-1., 18446744073709551615). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001dcb0d2f 5. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)0, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001d986e01 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 7. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 8. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 9. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 11. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 14. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 22. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 25. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 30. ? @ 0x00007fe1df9bbac3 31. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:37.471164 [ 48598 ] {c4eac5e2-bace-42bb-8ef1-42de0241a459} executeQuery: Code: 128. DB::Exception: Too many matches per row (> 1) in the result of function extractAllGroupsHorizontal: In scope SELECT extractAllGroupsHorizontal('hello world', '(\\w+)') SETTINGS regexp_max_matches_per_row = 1. (TOO_LARGE_ARRAY_SIZE) (version 24.3.12.76.altinitystable) (from [::1]:59026) (comment: 01246_extractAllGroupsHorizontal.sql) (in query: SELECT extractAllGroupsHorizontal('hello world', '(\\w+)') SETTINGS regexp_max_matches_per_row = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception const&, String>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, String&&) @ 0x000000001b8667f3 4. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86566d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:37.471362 [ 48598 ] {c4eac5e2-bace-42bb-8ef1-42de0241a459} TCPHandler: Code: 128. DB::Exception: Too many matches per row (> 1) in the result of function extractAllGroupsHorizontal: In scope SELECT extractAllGroupsHorizontal('hello world', '(\\w+)') SETTINGS regexp_max_matches_per_row = 1. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception const&, String>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, String&&) @ 0x000000001b8667f3 4. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b86566d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:15:37.520606 [ 23611 ] {b065d820-3a3c-47df-aa02-bcd6014f031f} executeQuery: Code: 42. DB::Exception: Function greatest cannot be called without arguments: In scope SELECT Greatest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:59028) (comment: 01246_least_greatest_generic.sql) (in query: SELECT Greatest();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)1, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c97ffb2 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:37.520799 [ 23611 ] {b065d820-3a3c-47df-aa02-bcd6014f031f} TCPHandler: Code: 42. DB::Exception: Function greatest cannot be called without arguments: In scope SELECT Greatest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)1, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c97ffb2 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001904561f 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.038321 [ 23573 ] {361f35a6-f9b3-463c-b7ef-e23ec37a91b7} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 100.00 thousand, current rows: 194.63 thousand: While executing NumbersRange. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:59180) (comment: 01231_log_queries_min_type.sql) (in query: select '01231_log_queries_min_type/EXCEPTION_WHILE_PROCESSING', max(number) from system.numbers limit 1e6;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f3d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 9. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 10. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.038624 [ 23573 ] {361f35a6-f9b3-463c-b7ef-e23ec37a91b7} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 100.00 thousand, current rows: 194.63 thousand: While executing NumbersRange. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f3d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 9. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 10. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.103849 [ 48602 ] {0e543b3f-cbff-4ef5-9b4c-3ee6fd4cea21} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has interior rings defined outside the outer boundary: In scope SELECT pointInPolygon((97.641933, 16.5076538), [(97.66905, 16.5026053), (97.667878, 16.4979175), (97.661433, 16.4917645), (97.656745, 16.4859047), (97.656745, 16.4818029), (97.658796, 16.4785801), (97.665535, 16.4753572), (97.670808, 16.4730135), (97.676082, 16.4697907), (97.680477, 16.4677398), (97.68575, 16.4686189), (97.689559, 16.4727207), (97.69454, 16.4744788), (97.698055, 16.4747718), (97.702157, 16.4724279), (97.703036, 16.4683261), (97.703036, 16.4633453), (97.702451, 16.4594354), (97.699533, 16.4539205), (97.699106, 16.4521467), (97.699896, 16.4500714), (97.701852, 16.4474887), (97.701272, 16.4460233), (97.699896, 16.4439216), (97.699857, 16.4425297), (97.700705, 16.4417585), (97.699266, 16.4404319), (97.696817, 16.439585), (97.69468, 16.4391501), (97.690854, 16.439294), (97.686571, 16.4407665), (97.683728, 16.4428458), (97.680647, 16.444719), (97.678369, 16.445322), (97.675195, 16.4448526), (97.672627, 16.4435941), (97.670568, 16.4419727), (97.667276, 16.4410039), (97.666215, 16.439402), (97.66599, 16.43656), (97.664579, 16.435632), (97.66195, 16.4344612), (97.659174, 16.4324549), (97.658693, 16.4290256), (97.659289, 16.4246502), (97.660882, 16.422609), (97.663533, 16.4225057), (97.666402, 16.4210711), (97.67148, 16.4170395), (97.673433, 16.4146478), (97.674184, 16.4124121), (97.6742, 16.4085257), (97.674894, 16.4055148), (97.675906, 16.4019452), (97.675287, 16.3996593), (97.675062, 16.3963334), (97.675798, 16.3936434), (97.675676, 16.3909321), (97.67508, 16.386655), (97.679839, 16.386241), (97.689403, 16.3726191), (97.692011, 16.372909), (97.696359, 16.3679819), (97.699866, 16.360968), (97.697233, 16.3609438), (97.693077, 16.3596272), (97.686631, 16.3584552), (97.68165, 16.3558182), (97.674619, 16.3496653), (97.667588, 16.3482003), (97.664072, 16.3502511), (97.659384, 16.3540599), (97.652353, 16.3578686), (97.649716, 16.3625565), (97.650595, 16.3672443), (97.65206, 16.3701742), (97.65206, 16.3733971), (97.651181, 16.3760339), (97.646493, 16.3763268), (97.6462, 16.3801357), (97.646786, 16.3851165), (97.643563, 16.3883393), (97.638583, 16.3889252), (97.636239, 16.392148), (97.630379, 16.3933199), (97.629132, 16.3964903), (97.624347, 16.4056104), (97.615377, 16.4165245), (97.614779, 16.4229534), (97.611938, 16.4335685), (97.613882, 16.4410439), (97.619713, 16.4461272), (97.62375, 16.4542007), (97.62345, 16.4640683), (97.618965, 16.4793181), (97.617321, 16.4884382), (97.617747, 16.4985751), (97.623301, 16.5026416), (97.629303, 16.5016624), (97.63272, 16.4986048), (97.640862, 16.498226), (97.647134, 16.5006382), (97.650873, 16.5051263), (97.654987, 16.5089598), (97.65639, 16.5118583), (97.658166, 16.5160658), (97.660395, 16.5197566), (97.66612, 16.5140318), (97.668757, 16.507879), (97.66905, 16.5026053)], [(97.666491, 16.5599384), (97.665077, 16.5589283), (97.662417, 16.5607013), (97.659315, 16.5700096), (97.655104, 16.5821991), (97.654882, 16.5855235), (97.654593, 16.5931971), (97.659381, 16.5957754), (97.669927, 16.5995844), (97.683111, 16.6022215), (97.695123, 16.6028077), (97.704206, 16.5984131), (97.704499, 16.5825917), (97.70007, 16.5731793), (97.698976, 16.572997), (97.697211, 16.5717833), (97.692114, 16.5691237), (97.684358, 16.5691235), (97.675936, 16.567572), (97.66818, 16.5611446), (97.666491, 16.5599384)], [(97.653232, 16.574263), (97.652445, 16.5679244), (97.655949, 16.5683449), (97.659594, 16.5627383), (97.659734, 16.5585335), (97.662257, 16.5550293), (97.660855, 16.5512449), (97.658613, 16.5490023), (97.659173, 16.544517), (97.654407, 16.5408727), (97.641933, 16.5363874), (97.63086, 16.5303604), (97.628057, 16.5312014), (97.625954, 16.5415736), (97.63072, 16.5613367), (97.638569, 16.5820811), (97.645017, 16.5892294), (97.649743, 16.5887155), (97.653232, 16.574263)], [(97.625696, 16.5488739), (97.623579, 16.5396268), (97.620589, 16.5423678), (97.616353, 16.5530826), (97.611619, 16.5637974), (97.61112, 16.5725187), (97.613339, 16.5792777), (97.635042, 16.5874696), (97.64152, 16.5981844), (97.643015, 16.605909), (97.645756, 16.6066565), (97.650989, 16.6034172), (97.644012, 16.5984335), (97.64219, 16.5877556), (97.636038, 16.5804926), (97.63252, 16.570307), (97.628314, 16.5603089), (97.625696, 16.5488739)], [(97.607902, 16.3798949), (97.604911, 16.3719709), (97.602519, 16.3749612), (97.601323, 16.3955933), (97.604014, 16.406059), (97.604762, 16.4084511), (97.607896, 16.4081673), (97.609397, 16.397537), (97.609397, 16.3882674), (97.607902, 16.3798949)], [(97.64902, 16.5107163), (97.645437, 16.5073734), (97.641933, 16.5076538), (97.641933, 16.5108776), (97.645717, 16.5160636), (97.651112, 16.5211243), (97.655721, 16.5238328), (97.656392, 16.5184349), (97.654359, 16.515696), (97.64902, 16.5107163)]). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37434) (comment: 01213_point_in_Myanmar.sql) (in query: SELECT pointInPolygon((97.641933, 16.5076538), [(97.66905, 16.5026053), (97.667878, 16.4979175), (97.661433, 16.4917645), (97.656745, 16.4859047), (97.656745, 16.4818029), (97.658796, 16.4785801), (97.665535, 16.4753572), (97.670808, 16.4730135), (97.676082, 16.4697907), (97.680477, 16.4677398), (97.68575, 16.4686189), (97.689559, 16.4727207), (97.69454, 16.4744788), (97.698055, 16.4747718), (97.702157, 16.4724279), (97.703036, 16.4683261), (97.703036, 16.4633453), (97.702451, 16.4594354), (97.699533, 16.4539205), (97.699106, 16.4521467), (97.699896, 16.4500714), (97.701852, 16.4474887), (97.701272, 16.4460233), (97.699896, 16.4439216), (97.699857, 16.4425297), (97.700705, 16.4417585), (97.699266, 16.4404319), (97.696817, 16.439585), (97.69468, 16.4391501), (97.690854, 16.439294), (97.686571, 16.4407665), (97.683728, 16.4428458), (97.680647, 16.444719), (97.678369, 16.445322), (97.675195, 16.4448526), (97.672627, 16.4435941), (97.670568, 16.4419727), (97.667276, 16.4410039), (97.666215, 16.439402), (97.66599, 16.43656), (97.664579, 16.435632), (97.66195, 16.4344612), (97.659174, 16.4324549), (97.658693, 16.4290256), (97.659289, 16.4246502), (97.660882, 16.422609), (97.663533, 16.4225057), (97.666402, 16.4210711), (97.67148, 16.4170395), (97.673433, 16.4146478), (97.674184, 16.4124121), (97.6742, 16.4085257), (97.674894, 16.4055148), (97.675906, 16.4019452), (97.675287, 16.3996593), (97.675062, 16.3963334), (97.675798, 16.3936434), (97.675676, 16.3909321), (97.67508, 16.386655), (97.679839, 16.386241), (97.689403, 16.3726191), (97.692011, 16.372909), (97.696359, 16.3679819), (97.699866, 16.360968), (97.697233, 16.3609438), (97.693077, 16.3596272), (97.686631, 16.3584552), (97.68165, 16.3558182), (97.674619, 16.3496653), (97.667588, 16.3482003), (97.664072, 16.3502511), (97.659384, 16.3540599), (97.652353, 16.3578686), (97.649716, 16.3625565), (97.650595, 16.3672443), (97.65206, 16.3701742), (97.65206, 16.3733971), (97.651181, 16.3760339), (97.646493, 16.3763268), (97.6462, 16.3801357), (97.646786, 16.3851165), (97.643563, 16.3883393), (97.638583, 16.3889252), (97.636239, 16.392148), (97.630379, 16.3933199), (97.629132, 16.3964903), (97.624347, 16.4056104), (97.615377, 16.4165245), (97.614779, 16.4229534), (97.611938, 16.4335685), (97.613882, 16.4410439), (97.619713, 16.4461272), (97.62375, 16.4542007), (97.62345, 16.4640683), (97.618965, 16.4793181), (97.617321, 16.4884382), (97.617747, 16.4985751), (97.623301, 16.5026416), (97.629303, 16.5016624), (97.63272, 16.4986048), (97.640862, 16.498226), (97.647134, 16.5006382), (97.650873, 16.5051263), (97.654987, 16.5089598), (97.65639, 16.5118583), (97.658166, 16.5160658), (97.660395, 16.5197566), (97.66612, 16.5140318), (97.668757, 16.507879), (97.66905, 16.5026053)], [(97.666491, 16.5599384), (97.665077, 16.5589283), (97.662417, 16.5607013), (97.659315, 16.5700096), (97.655104, 16.5821991), (97.654882, 16.5855235), (97.654593, 16.5931971), (97.659381, 16.5957754), (97.669927, 16.5995844), (97.683111, 16.6022215), (97.695123, 16.6028077), (97.704206, 16.5984131), (97.704499, 16.5825917), (97.70007, 16.5731793), (97.698976, 16.572997), (97.697211, 16.5717833), (97.692114, 16.5691237), (97.684358, 16.5691235), (97.675936, 16.567572), (97.66818, 16.5611446), (97.666491, 16.5599384)], [(97.653232, 16.574263), (97.652445, 16.5679244), (97.655949, 16.5683449), (97.659594, 16.5627383), (97.659734, 16.5585335), (97.662257, 16.5550293), (97.660855, 16.5512449), (97.658613, 16.5490023), (97.659173, 16.544517), (97.654407, 16.5408727), (97.641933, 16.5363874), (97.63086, 16.5303604), (97.628057, 16.5312014), (97.625954, 16.5415736), (97.63072, 16.5613367), (97.638569, 16.5820811), (97.645017, 16.5892294), (97.649743, 16.5887155), (97.653232, 16.574263)], [(97.625696, 16.5488739), (97.623579, 16.5396268), (97.620589, 16.5423678), (97.616353, 16.5530826), (97.611619, 16.5637974), (97.61112, 16.5725187), (97.613339, 16.5792777), (97.635042, 16.5874696), (97.64152, 16.5981844), (97.643015, 16.605909), (97.645756, 16.6066565), (97.650989, 16.6034172), (97.644012, 16.5984335), (97.64219, 16.5877556), (97.636038, 16.5804926), (97.63252, 16.570307), (97.628314, 16.5603089), (97.625696, 16.5488739)], [(97.607902, 16.3798949), (97.604911, 16.3719709), (97.602519, 16.3749612), (97.601323, 16.3955933), (97.604014, 16.406059), (97.604762, 16.4084511), (97.607896, 16.4081673), (97.609397, 16.397537), (97.609397, 16.3882674), (97.607902, 16.3798949)], [(97.64902, 16.5107163), (97.645437, 16.5073734), (97.641933, 16.5076538), (97.641933, 16.5108776), (97.645717, 16.5160636), (97.651112, 16.5211243), (97.655721, 16.5238328), (97.656392, 16.5184349), (97.654359, 16.515696), (97.64902, 16.5107163)]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. DB::(anonymous namespace)::FunctionPointInPolygon>::parseConstPolygon(std::vector> const&, boost::geometry::model::polygon, false, true, std::vector, std::vector, std::allocator, std::allocator>&) const @ 0x0000000020cb90e6 5. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020cb35d7 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:39.104384 [ 48602 ] {0e543b3f-cbff-4ef5-9b4c-3ee6fd4cea21} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has interior rings defined outside the outer boundary: In scope SELECT pointInPolygon((97.641933, 16.5076538), [(97.66905, 16.5026053), (97.667878, 16.4979175), (97.661433, 16.4917645), (97.656745, 16.4859047), (97.656745, 16.4818029), (97.658796, 16.4785801), (97.665535, 16.4753572), (97.670808, 16.4730135), (97.676082, 16.4697907), (97.680477, 16.4677398), (97.68575, 16.4686189), (97.689559, 16.4727207), (97.69454, 16.4744788), (97.698055, 16.4747718), (97.702157, 16.4724279), (97.703036, 16.4683261), (97.703036, 16.4633453), (97.702451, 16.4594354), (97.699533, 16.4539205), (97.699106, 16.4521467), (97.699896, 16.4500714), (97.701852, 16.4474887), (97.701272, 16.4460233), (97.699896, 16.4439216), (97.699857, 16.4425297), (97.700705, 16.4417585), (97.699266, 16.4404319), (97.696817, 16.439585), (97.69468, 16.4391501), (97.690854, 16.439294), (97.686571, 16.4407665), (97.683728, 16.4428458), (97.680647, 16.444719), (97.678369, 16.445322), (97.675195, 16.4448526), (97.672627, 16.4435941), (97.670568, 16.4419727), (97.667276, 16.4410039), (97.666215, 16.439402), (97.66599, 16.43656), (97.664579, 16.435632), (97.66195, 16.4344612), (97.659174, 16.4324549), (97.658693, 16.4290256), (97.659289, 16.4246502), (97.660882, 16.422609), (97.663533, 16.4225057), (97.666402, 16.4210711), (97.67148, 16.4170395), (97.673433, 16.4146478), (97.674184, 16.4124121), (97.6742, 16.4085257), (97.674894, 16.4055148), (97.675906, 16.4019452), (97.675287, 16.3996593), (97.675062, 16.3963334), (97.675798, 16.3936434), (97.675676, 16.3909321), (97.67508, 16.386655), (97.679839, 16.386241), (97.689403, 16.3726191), (97.692011, 16.372909), (97.696359, 16.3679819), (97.699866, 16.360968), (97.697233, 16.3609438), (97.693077, 16.3596272), (97.686631, 16.3584552), (97.68165, 16.3558182), (97.674619, 16.3496653), (97.667588, 16.3482003), (97.664072, 16.3502511), (97.659384, 16.3540599), (97.652353, 16.3578686), (97.649716, 16.3625565), (97.650595, 16.3672443), (97.65206, 16.3701742), (97.65206, 16.3733971), (97.651181, 16.3760339), (97.646493, 16.3763268), (97.6462, 16.3801357), (97.646786, 16.3851165), (97.643563, 16.3883393), (97.638583, 16.3889252), (97.636239, 16.392148), (97.630379, 16.3933199), (97.629132, 16.3964903), (97.624347, 16.4056104), (97.615377, 16.4165245), (97.614779, 16.4229534), (97.611938, 16.4335685), (97.613882, 16.4410439), (97.619713, 16.4461272), (97.62375, 16.4542007), (97.62345, 16.4640683), (97.618965, 16.4793181), (97.617321, 16.4884382), (97.617747, 16.4985751), (97.623301, 16.5026416), (97.629303, 16.5016624), (97.63272, 16.4986048), (97.640862, 16.498226), (97.647134, 16.5006382), (97.650873, 16.5051263), (97.654987, 16.5089598), (97.65639, 16.5118583), (97.658166, 16.5160658), (97.660395, 16.5197566), (97.66612, 16.5140318), (97.668757, 16.507879), (97.66905, 16.5026053)], [(97.666491, 16.5599384), (97.665077, 16.5589283), (97.662417, 16.5607013), (97.659315, 16.5700096), (97.655104, 16.5821991), (97.654882, 16.5855235), (97.654593, 16.5931971), (97.659381, 16.5957754), (97.669927, 16.5995844), (97.683111, 16.6022215), (97.695123, 16.6028077), (97.704206, 16.5984131), (97.704499, 16.5825917), (97.70007, 16.5731793), (97.698976, 16.572997), (97.697211, 16.5717833), (97.692114, 16.5691237), (97.684358, 16.5691235), (97.675936, 16.567572), (97.66818, 16.5611446), (97.666491, 16.5599384)], [(97.653232, 16.574263), (97.652445, 16.5679244), (97.655949, 16.5683449), (97.659594, 16.5627383), (97.659734, 16.5585335), (97.662257, 16.5550293), (97.660855, 16.5512449), (97.658613, 16.5490023), (97.659173, 16.544517), (97.654407, 16.5408727), (97.641933, 16.5363874), (97.63086, 16.5303604), (97.628057, 16.5312014), (97.625954, 16.5415736), (97.63072, 16.5613367), (97.638569, 16.5820811), (97.645017, 16.5892294), (97.649743, 16.5887155), (97.653232, 16.574263)], [(97.625696, 16.5488739), (97.623579, 16.5396268), (97.620589, 16.5423678), (97.616353, 16.5530826), (97.611619, 16.5637974), (97.61112, 16.5725187), (97.613339, 16.5792777), (97.635042, 16.5874696), (97.64152, 16.5981844), (97.643015, 16.605909), (97.645756, 16.6066565), (97.650989, 16.6034172), (97.644012, 16.5984335), (97.64219, 16.5877556), (97.636038, 16.5804926), (97.63252, 16.570307), (97.628314, 16.5603089), (97.625696, 16.5488739)], [(97.607902, 16.3798949), (97.604911, 16.3719709), (97.602519, 16.3749612), (97.601323, 16.3955933), (97.604014, 16.406059), (97.604762, 16.4084511), (97.607896, 16.4081673), (97.609397, 16.397537), (97.609397, 16.3882674), (97.607902, 16.3798949)], [(97.64902, 16.5107163), (97.645437, 16.5073734), (97.641933, 16.5076538), (97.641933, 16.5108776), (97.645717, 16.5160636), (97.651112, 16.5211243), (97.655721, 16.5238328), (97.656392, 16.5184349), (97.654359, 16.515696), (97.64902, 16.5107163)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x00000000180925eb 4. DB::(anonymous namespace)::FunctionPointInPolygon>::parseConstPolygon(std::vector> const&, boost::geometry::model::polygon, false, true, std::vector, std::vector, std::allocator, std::allocator>&) const @ 0x0000000020cb90e6 5. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020cb35d7 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 12. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 15. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 21. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 26. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 31. ? @ 0x00007fe1df9bbac3 2025.03.05 21:15:39.125302 [ 23573 ] {777df3e1-07a7-4584-a3c2-fad658108c9f} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 100.00 thousand, current rows: 194.63 thousand: While executing NumbersRange. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:59180) (comment: 01231_log_queries_min_type.sql) (in query: select '01231_log_queries_min_type w/ Settings/EXCEPTION_WHILE_PROCESSING', max(number) from system.numbers limit 1e6;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f3d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 9. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 10. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.125593 [ 23573 ] {777df3e1-07a7-4584-a3c2-fad658108c9f} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 100.00 thousand, current rows: 194.63 thousand: While executing NumbersRange. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002f428f3d 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c899 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 9. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 10. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.283519 [ 23562 ] {ed35e3a7-103c-4ebf-addc-f25b7a6a4255} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key key1 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:37486) (comment: 01213_alter_rename_primary_key_zookeeper_long.sql) (in query: ALTER TABLE table_for_rename_pk RENAME COLUMN key1 TO renamed_key1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4348e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.283654 [ 23562 ] {ed35e3a7-103c-4ebf-addc-f25b7a6a4255} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key key1 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4348e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.286930 [ 23562 ] {881d9547-6961-4d6e-8586-e55b2de11c2f} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key key3 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:37486) (comment: 01213_alter_rename_primary_key_zookeeper_long.sql) (in query: ALTER TABLE table_for_rename_pk RENAME COLUMN key3 TO renamed_key3;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4348e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.287099 [ 23562 ] {881d9547-6961-4d6e-8586-e55b2de11c2f} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key key3 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4348e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.289862 [ 23562 ] {a973408e-ac7c-4f99-a1ae-db8c8ee1ebd9} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key key2 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:37486) (comment: 01213_alter_rename_primary_key_zookeeper_long.sql) (in query: ALTER TABLE table_for_rename_pk RENAME COLUMN key2 TO renamed_key2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4348e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.290019 [ 23562 ] {a973408e-ac7c-4f99-a1ae-db8c8ee1ebd9} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key key2 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4348e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.377263 [ 23562 ] {e80aa0dd-97c8-4d3e-a4be-1b2d1d151c88} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key key1 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:37486) (comment: 01213_alter_rename_primary_key_zookeeper_long.sql) (in query: ALTER TABLE table_for_rename_with_primary_key RENAME COLUMN key1 TO renamed_key1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4348e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.377377 [ 23562 ] {e80aa0dd-97c8-4d3e-a4be-1b2d1d151c88} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key key1 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4348e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.379330 [ 23562 ] {7c9d4938-e6a8-4063-bb24-2b47106adf46} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key key2 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:37486) (comment: 01213_alter_rename_primary_key_zookeeper_long.sql) (in query: ALTER TABLE table_for_rename_with_primary_key RENAME COLUMN key2 TO renamed_key2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4348e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.379431 [ 23562 ] {7c9d4938-e6a8-4063-bb24-2b47106adf46} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key key2 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4348e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.381353 [ 23562 ] {7ba4eb2b-26d0-4553-b312-e1e9abd9c103} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key key3 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.3.12.76.altinitystable) (from [::1]:37486) (comment: 01213_alter_rename_primary_key_zookeeper_long.sql) (in query: ALTER TABLE table_for_rename_with_primary_key RENAME COLUMN key3 TO renamed_key3;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4348e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.381448 [ 23562 ] {7ba4eb2b-26d0-4553-b312-e1e9abd9c103} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key key3 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000032b4348e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307951ff 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.746846 [ 14920 ] {8f9acce8-375d-4d6e-ba98-7b6a45033833} executeQuery: Code: 15. DB::Exception: Cannot rename to `value2`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.3.12.76.altinitystable) (from [::1]:37578) (comment: 01213_alter_rename_column.sql) (in query: ALTER TABLE table_for_rename RENAME COLUMN value3 to value2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a73b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.747116 [ 14920 ] {8f9acce8-375d-4d6e-ba98-7b6a45033833} TCPHandler: Code: 15. DB::Exception: Cannot rename to `value2`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a73b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.768695 [ 14920 ] {1344b353-7006-4c40-8aef-c9ae0ab0cbce} executeQuery: Code: 36. DB::Exception: Cannot rename column '`value3`' to two different names in a single ALTER query. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:37578) (comment: 01213_alter_rename_column.sql) (in query: ALTER TABLE table_for_rename RENAME COLUMN value3 TO r1, RENAME COLUMN value3 TO r2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032089a44 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.769014 [ 14920 ] {1344b353-7006-4c40-8aef-c9ae0ab0cbce} TCPHandler: Code: 36. DB::Exception: Cannot rename column '`value3`' to two different names in a single ALTER query. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032089a44 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.788904 [ 14920 ] {a10b4aec-237c-4bd3-a51f-ac0869128d85} executeQuery: Code: 48. DB::Exception: Transitive renames in a single ALTER query are not allowed (don't make sense). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:37578) (comment: 01213_alter_rename_column.sql) (in query: ALTER TABLE table_for_rename RENAME COLUMN value3 TO r1, RENAME COLUMN r1 TO value1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/AlterCommands.cpp:1487: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032089983 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.789158 [ 14920 ] {a10b4aec-237c-4bd3-a51f-ac0869128d85} TCPHandler: Code: 48. DB::Exception: Transitive renames in a single ALTER query are not allowed (don't make sense). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/AlterCommands.cpp:1487: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032089983 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.825086 [ 14920 ] {c139f5df-1899-4d97-bc2d-2f1d4155c166} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value100` to rename. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.3.12.76.altinitystable) (from [::1]:37578) (comment: 01213_alter_rename_column.sql) (in query: ALTER TABLE table_for_rename RENAME COLUMN value100 to renamed_value100;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Storages/AlterCommands.cpp:1507: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a66f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:39.825216 [ 14920 ] {c139f5df-1899-4d97-bc2d-2f1d4155c166} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value100` to rename. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000018778a96 4. ./build_docker/./src/Storages/AlterCommands.cpp:1507: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003208a66f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795158 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:43.844224 [ 23597 ] {1983a3f9-627b-49fe-a584-635c6e15d993} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:38430) (comment: 01178_int_field_to_decimal.sql) (in query: select d from values('d Decimal(8, 8)', 0, 1) where d not in (-1, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x000000003169fcde 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031695a54 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:609: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169a90f 8. ./contrib/llvm-project/libcxx/include/vector:1457: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4827c6 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 10. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:43.844403 [ 23597 ] {1983a3f9-627b-49fe-a584-635c6e15d993} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x000000003169fcde 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031695a54 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:609: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169a90f 8. ./contrib/llvm-project/libcxx/include/vector:1457: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4827c6 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 10. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:43.846565 [ 23597 ] {e970c5d4-0026-441b-b305-77e28f29c33f} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:38430) (comment: 01178_int_field_to_decimal.sql) (in query: select d from values('d Decimal(8, 8)', 0, 2) where d not in (1, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x000000003169fcde 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031695a54 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:609: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169a90f 8. ./contrib/llvm-project/libcxx/include/vector:1457: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4827c6 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 10. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:43.846686 [ 23597 ] {e970c5d4-0026-441b-b305-77e28f29c33f} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x000000003169fcde 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031695a54 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:609: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x000000003169a90f 8. ./contrib/llvm-project/libcxx/include/vector:1457: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e4827c6 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 10. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:43.868041 [ 23597 ] {54ea9ae2-5c2b-442f-88da-53fd452b5e1a} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:38430) (comment: 01178_int_field_to_decimal.sql) (in query: select d from values('d Decimal(9, 8)', 0, 3) where d not in (-9223372036854775808, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x00000000316a0122 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031695a54 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 7. ./src/Core/Field.h:450: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&) @ 0x000000003169aece 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000030944ddf 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103c1c6 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 11. ./build_docker/./src/Planner/CollectSets.cpp:121: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003103b763 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008ed2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:43.868248 [ 23597 ] {54ea9ae2-5c2b-442f-88da-53fd452b5e1a} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x00000000316a0122 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031695a54 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 7. ./src/Core/Field.h:450: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&) @ 0x000000003169aece 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000030944ddf 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103c1c6 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 11. ./build_docker/./src/Planner/CollectSets.cpp:121: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003103b763 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008ed2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:43.889378 [ 23597 ] {b7d8dbe9-bc8e-48cd-bfc1-6bc8f06d6476} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:38430) (comment: 01178_int_field_to_decimal.sql) (in query: select d from values('d Decimal(9, 8)', 0, 4) where d not in (18446744073709551615, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x000000003169fcde 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031695a54 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 7. ./src/Core/Field.h:450: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&) @ 0x000000003169aece 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000030944ddf 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103c1c6 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 11. ./build_docker/./src/Planner/CollectSets.cpp:121: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003103b763 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008ed2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:43.891035 [ 23597 ] {b7d8dbe9-bc8e-48cd-bfc1-6bc8f06d6476} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x000000003169fcde 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031695a54 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 7. ./src/Core/Field.h:450: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&) @ 0x000000003169aece 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000030944ddf 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103c1c6 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 11. ./build_docker/./src/Planner/CollectSets.cpp:121: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003103b763 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008ed2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:43.913392 [ 23597 ] {fd147d75-7be9-41cc-986c-860725d89792} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:38430) (comment: 01178_int_field_to_decimal.sql) (in query: select d from values('d Decimal(18, 8)', 0, 5) where d not in (-9223372036854775808, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x00000000316a1642 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031695a99 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 7. ./src/Core/Field.h:450: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&) @ 0x000000003169aece 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000030944ddf 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103c1c6 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 11. ./build_docker/./src/Planner/CollectSets.cpp:121: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003103b763 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008ed2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:43.913634 [ 23597 ] {fd147d75-7be9-41cc-986c-860725d89792} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x00000000316a1642 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031695a99 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 7. ./src/Core/Field.h:450: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&) @ 0x000000003169aece 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000030944ddf 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103c1c6 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 11. ./build_docker/./src/Planner/CollectSets.cpp:121: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003103b763 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008ed2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:43.934124 [ 23597 ] {bb5816d9-c351-4838-a91c-513fe924b800} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:38430) (comment: 01178_int_field_to_decimal.sql) (in query: select d from values('d Decimal(18, 8)', 0, 6) where d not in (18446744073709551615, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x00000000316a11fe 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031695a99 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 7. ./src/Core/Field.h:450: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&) @ 0x000000003169aece 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000030944ddf 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103c1c6 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 11. ./build_docker/./src/Planner/CollectSets.cpp:121: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003103b763 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008ed2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:43.934300 [ 23597 ] {bb5816d9-c351-4838-a91c-513fe924b800} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x00000000316a11fe 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031695a99 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 7. ./src/Core/Field.h:450: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&) @ 0x000000003169aece 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000030944ddf 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103c1c6 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 11. ./build_docker/./src/Planner/CollectSets.cpp:121: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003103b763 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008ed2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:43.954354 [ 23597 ] {be7cee43-8b7a-41cb-9ed3-7326f3929c72} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(26, 8). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:38430) (comment: 01178_int_field_to_decimal.sql) (in query: select d from values('d Decimal(26, 8)', 0, 7) where d not in (-9223372036854775808, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x00000000316a275e 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031695ac1 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 7. ./src/Core/Field.h:450: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&) @ 0x000000003169aece 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000030944ddf 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103c1c6 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 11. ./build_docker/./src/Planner/CollectSets.cpp:121: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003103b763 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008ed2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:43.954514 [ 23597 ] {be7cee43-8b7a-41cb-9ed3-7326f3929c72} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(26, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x00000000316a275e 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031695ac1 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 7. ./src/Core/Field.h:450: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&) @ 0x000000003169aece 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000030944ddf 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103c1c6 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 11. ./build_docker/./src/Planner/CollectSets.cpp:121: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003103b763 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008ed2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:43.974365 [ 23597 ] {559dc731-1f65-4cb1-b06d-1bfcd2e312c5} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(27, 8). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:38430) (comment: 01178_int_field_to_decimal.sql) (in query: select d from values('d Decimal(27, 8)', 0, 8) where d not in (18446744073709551615, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x00000000316a2d14 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031695ac1 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 7. ./src/Core/Field.h:450: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&) @ 0x000000003169aece 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000030944ddf 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103c1c6 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 11. ./build_docker/./src/Planner/CollectSets.cpp:121: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003103b763 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008ed2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:43.974514 [ 23597 ] {559dc731-1f65-4cb1-b06d-1bfcd2e312c5} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(27, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x00000000316a2d14 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031695ac1 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000031694c25 7. ./src/Core/Field.h:450: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&) @ 0x000000003169aece 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000030944ddf 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103c1c6 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003103ce8b 11. ./build_docker/./src/Planner/CollectSets.cpp:121: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003103b763 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildPlanForQueryNode() @ 0x0000000031008ed2 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.424262 [ 730 ] {c9ff9b2c-6a8e-44b8-99e0-26e49623a396} executeQuery: Code: 649. DB::Exception: There is no current transaction. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::1]:38516) (comment: 01173_transaction_control_queries.sql) (in query: commit), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:0: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x0000000031718651 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.424470 [ 730 ] {c9ff9b2c-6a8e-44b8-99e0-26e49623a396} TCPHandler: Code: 649. DB::Exception: There is no current transaction. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:0: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x0000000031718651 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.439221 [ 730 ] {cf215cb1-3378-4b50-8a6e-5e6ca9b85d8f} executeQuery: Code: 649. DB::Exception: There is no current transaction. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::1]:38516) (comment: 01173_transaction_control_queries.sql) (in query: rollback), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:0: DB::InterpreterTransactionControlQuery::executeRollback(std::shared_ptr) @ 0x0000000031718ee6 5. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:32: DB::InterpreterTransactionControlQuery::execute() @ 0x000000003171764b 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.439418 [ 730 ] {cf215cb1-3378-4b50-8a6e-5e6ca9b85d8f} TCPHandler: Code: 649. DB::Exception: There is no current transaction. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:0: DB::InterpreterTransactionControlQuery::executeRollback(std::shared_ptr) @ 0x0000000031718ee6 5. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:32: DB::InterpreterTransactionControlQuery::execute() @ 0x000000003171764b 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.540695 [ 730 ] {9d60f640-5c89-42d1-8c5d-91ed3776c98b} executeQuery: Code: 649. DB::Exception: Nested transactions are not supported. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::1]:38516) (comment: 01173_transaction_control_queries.sql) (in query: begin transaction), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:42: DB::InterpreterTransactionControlQuery::executeBegin(std::shared_ptr) @ 0x0000000031717ef6 5. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:28: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317175ce 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.540856 [ 730 ] {9d60f640-5c89-42d1-8c5d-91ed3776c98b} TCPHandler: Code: 649. DB::Exception: Nested transactions are not supported. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:42: DB::InterpreterTransactionControlQuery::executeBegin(std::shared_ptr) @ 0x0000000031717ef6 5. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:28: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317175ce 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.573390 [ 730 ] {55709c37-60a6-4948-93b6-413452b7f740} executeQuery: Code: 46. DB::Exception: Function with name 'functionThatDoesNotExist' does not exist. In scope SELECT functionThatDoesNotExist(). (UNKNOWN_FUNCTION) (version 24.3.12.76.altinitystable) (from [::1]:38516) (comment: 01173_transaction_control_queries.sql) (in query: -- rollback on exception before start select functionThatDoesNotExist();), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000002951b6a3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b7ba1 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.573538 [ 730 ] {55709c37-60a6-4948-93b6-413452b7f740} TCPHandler: Code: 46. DB::Exception: Function with name 'functionThatDoesNotExist' does not exist. In scope SELECT functionThatDoesNotExist(). (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000002951b6a3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b7ba1 5. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.589077 [ 730 ] {59df5d28-8de2-43b7-bf31-a8c9944106cc} executeQuery: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::1]:38516) (comment: 01173_transaction_control_queries.sql) (in query: -- cannot commit after exception commit), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.589276 [ 730 ] {59df5d28-8de2-43b7-bf31-a8c9944106cc} TCPHandler: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.591272 [ 730 ] {70c62dfc-617f-4d08-a48f-e24d48bed11d} executeQuery: Code: 649. DB::Exception: Nested transactions are not supported. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::1]:38516) (comment: 01173_transaction_control_queries.sql) (in query: begin transaction), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:42: DB::InterpreterTransactionControlQuery::executeBegin(std::shared_ptr) @ 0x0000000031717ef6 5. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:28: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317175ce 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.591356 [ 730 ] {70c62dfc-617f-4d08-a48f-e24d48bed11d} TCPHandler: Code: 649. DB::Exception: Nested transactions are not supported. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:42: DB::InterpreterTransactionControlQuery::executeBegin(std::shared_ptr) @ 0x0000000031717ef6 5. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:28: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317175ce 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.621004 [ 730 ] {aaa0b123-a122-40e5-8282-47e16b7137da} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(less(100_UInt8, __table1.number) :: 0) -> throwIf(less(100_UInt8, __table1.number)) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:38516) (comment: 01173_transaction_control_queries.sql) (in query: -- rollback on exception while processing select throwIf(100 < number) from numbers(1000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.621124 [ 730 ] {aaa0b123-a122-40e5-8282-47e16b7137da} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(less(100_UInt8, __table1.number) :: 0) -> throwIf(less(100_UInt8, __table1.number)) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000033b53261 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 19. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.623402 [ 730 ] {86af84e0-2a4c-448e-98df-b1bcaa0137e7} executeQuery: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::1]:38516) (comment: 01173_transaction_control_queries.sql) (in query: -- cannot commit after exception commit), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.623493 [ 730 ] {86af84e0-2a4c-448e-98df-b1bcaa0137e7} TCPHandler: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.637826 [ 730 ] {eaf45f72-4385-4dca-8178-80859d3bb7a0} executeQuery: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::1]:38516) (comment: 01173_transaction_control_queries.sql) (in query: insert into mt1 values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:888: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316ffc3f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.638074 [ 730 ] {eaf45f72-4385-4dca-8178-80859d3bb7a0} TCPHandler: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:888: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316ffc3f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.640129 [ 730 ] {ca11229e-8f96-48fa-9eca-2393c47a007a} executeQuery: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::1]:38516) (comment: 01173_transaction_control_queries.sql) (in query: insert into mt2 values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:888: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316ffc3f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.640243 [ 730 ] {ca11229e-8f96-48fa-9eca-2393c47a007a} TCPHandler: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:888: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316ffc3f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.641749 [ 730 ] {5d229ddf-8289-41da-95c8-40be842b72eb} executeQuery: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::1]:38516) (comment: 01173_transaction_control_queries.sql) (in query: select 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:888: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316ffc3f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.641864 [ 730 ] {5d229ddf-8289-41da-95c8-40be842b72eb} TCPHandler: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:888: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316ffc3f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.760898 [ 730 ] {5d91dd7b-f4a7-4604-a7b6-cefb73f16885} executeQuery: Code: 649. DB::Exception: Cannot set snapshot to reserved CSN. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::1]:38516) (comment: 01173_transaction_control_queries.sql) (in query: set transaction snapshot 5), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:0: DB::InterpreterTransactionControlQuery::executeSetSnapshot(std::shared_ptr, unsigned long) @ 0x000000003171923a 5. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:34: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317176de 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.761025 [ 730 ] {5d91dd7b-f4a7-4604-a7b6-cefb73f16885} TCPHandler: Code: 649. DB::Exception: Cannot set snapshot to reserved CSN. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:0: DB::InterpreterTransactionControlQuery::executeSetSnapshot(std::shared_ptr, unsigned long) @ 0x000000003171923a 5. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:34: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317176de 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.776281 [ 730 ] {0b1e7ec3-f0fa-41f6-802c-92ad1bb8fbe6} executeQuery: Code: 48. DB::Exception: Transactions are not supported for this type of query (CreateQuery__m). (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:38516) (comment: 01173_transaction_control_queries.sql) (in query: create table m (n int) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc327 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.776431 [ 730 ] {0b1e7ec3-f0fa-41f6-802c-92ad1bb8fbe6} TCPHandler: Code: 48. DB::Exception: Transactions are not supported for this type of query (CreateQuery__m). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc327 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.777805 [ 730 ] {f09f960e-c8be-4f95-9b1c-c7262d47cb4c} executeQuery: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::1]:38516) (comment: 01173_transaction_control_queries.sql) (in query: commit), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.777895 [ 730 ] {f09f960e-c8be-4f95-9b1c-c7262d47cb4c} TCPHandler: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.799008 [ 730 ] {63374248-40e1-4c79-adc5-a3a1eac66cf7} executeQuery: Code: 48. DB::Exception: Storage Memory (table test_oockkrb6.m (74a28ac8-1822-4629-8c52-e1727c569939)) does not support transactions. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:38516) (comment: 01173_transaction_control_queries.sql) (in query: insert into m values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:0: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000307a4ec8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bd5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.799298 [ 730 ] {63374248-40e1-4c79-adc5-a3a1eac66cf7} TCPHandler: Code: 48. DB::Exception: Storage Memory (table test_oockkrb6.m (74a28ac8-1822-4629-8c52-e1727c569939)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:0: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000307a4ec8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bd5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.801297 [ 730 ] {94f4a63f-df35-4f82-8c94-759d8f9cadf6} executeQuery: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::1]:38516) (comment: 01173_transaction_control_queries.sql) (in query: select * from m;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:888: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316ffc3f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.801424 [ 730 ] {94f4a63f-df35-4f82-8c94-759d8f9cadf6} TCPHandler: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:888: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316ffc3f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.803014 [ 730 ] {1898fd95-82f6-408c-9392-fdb26accc0ca} executeQuery: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::1]:38516) (comment: 01173_transaction_control_queries.sql) (in query: commit), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.803155 [ 730 ] {1898fd95-82f6-408c-9392-fdb26accc0ca} TCPHandler: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.807347 [ 730 ] {bbbee431-4c94-489b-ac4c-2f32dbdd0104} executeQuery: Code: 48. DB::Exception: Storage Memory (table test_oockkrb6.m (74a28ac8-1822-4629-8c52-e1727c569939)) does not support transactions. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:38516) (comment: 01173_transaction_control_queries.sql) (in query: select * from m;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100e642 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.807474 [ 730 ] {bbbee431-4c94-489b-ac4c-2f32dbdd0104} TCPHandler: Code: 48. DB::Exception: Storage Memory (table test_oockkrb6.m (74a28ac8-1822-4629-8c52-e1727c569939)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100e642 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.808714 [ 730 ] {3d806935-b6e3-4685-8cc7-83e07765a61f} executeQuery: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::1]:38516) (comment: 01173_transaction_control_queries.sql) (in query: commit), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:44.808862 [ 730 ] {3d806935-b6e3-4685-8cc7-83e07765a61f} TCPHandler: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 9. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:46.776672 [ 11338 ] {4cd70416-62b4-4077-be8c-c03282684230} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.8:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.8:8123'. Failed at try 10/10. 2025.03.05 21:15:46.790624 [ 11326 ] {4cd70416-62b4-4077-be8c-c03282684230} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.7:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.7:8123'. Failed at try 10/10. 2025.03.05 21:15:46.792947 [ 34576 ] {4cd70416-62b4-4077-be8c-c03282684230} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.10:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.10:8123'. Failed at try 10/10. 2025.03.05 21:15:46.804087 [ 6286 ] {4cd70416-62b4-4077-be8c-c03282684230} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.3:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.3:8123'. Failed at try 10/10. 2025.03.05 21:15:46.804249 [ 5913 ] {4cd70416-62b4-4077-be8c-c03282684230} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.9:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.9:8123'. Failed at try 10/10. 2025.03.05 21:15:46.808930 [ 11244 ] {4cd70416-62b4-4077-be8c-c03282684230} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.5:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.5:8123'. Failed at try 10/10. 2025.03.05 21:15:46.809023 [ 11314 ] {4cd70416-62b4-4077-be8c-c03282684230} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.1:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.1:8123'. Failed at try 10/10. 2025.03.05 21:15:46.816933 [ 11465 ] {4cd70416-62b4-4077-be8c-c03282684230} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.2:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.2:8123'. Failed at try 10/10. 2025.03.05 21:15:46.827957 [ 34663 ] {4cd70416-62b4-4077-be8c-c03282684230} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.4:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.4:8123'. Failed at try 10/10. 2025.03.05 21:15:46.829018 [ 1845 ] {4cd70416-62b4-4077-be8c-c03282684230} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.6:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.6:8123'. Failed at try 10/10. 2025.03.05 21:15:46.858527 [ 23577 ] {4cd70416-62b4-4077-be8c-c03282684230} executeQuery: Poco::Exception. Code: 1000, e.code() = 0, Timeout: connect timed out: 128.0.0.1:8123 (version 24.3.12.76.altinitystable) (from [::1]:53964) (comment: 02044_url_glob_parallel_connection_refused.sh) (in query: SELECT * FROM url('http://128.0.0.{1..10}:8123/?query=SELECT+sleep(1)', TSV, 'x UInt8')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:37: Poco::Exception::Exception(String const&, String const&, int) @ 0x000000003697aad2 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:148: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x0000000036981c9b 3. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000367ad1eb 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:214: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x000000003677648a 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:0: Poco::Net::HTTPClientSession::reconnect() @ 0x0000000036752c54 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c7216 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:540: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c51d9 8. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration) @ 0x0000000024ab5256 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:246: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000290691b5 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x0000000024735e3d 17. DB::ReadBuffer::next() @ 0x0000000018778250 18. ./src/IO/ReadHelpers.h:1832: DB::skipBOMIfExists(DB::ReadBuffer&) @ 0x00000000336c0912 19. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:79: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x00000000336b545d 20. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:103: DB::IRowInputFormat::read() @ 0x0000000033662a38 21. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 22. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 26. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 28. ./build_docker/./src/Storages/StorageURL.cpp:406: DB::StorageURLSource::generate() @ 0x00000000326594a1 29. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 2025.03.05 21:15:46.859892 [ 23577 ] {4cd70416-62b4-4077-be8c-c03282684230} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:53964). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:46.859961 [ 23577 ] {4cd70416-62b4-4077-be8c-c03282684230} TCPHandler: Code: 1000. DB::Exception: Timeout: connect timed out: 128.0.0.1:8123. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:37: Poco::Exception::Exception(String const&, String const&, int) @ 0x000000003697aad2 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:148: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x0000000036981c9b 3. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000367ad1eb 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:214: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x000000003677648a 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:0: Poco::Net::HTTPClientSession::reconnect() @ 0x0000000036752c54 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c7216 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:540: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c51d9 8. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration) @ 0x0000000024ab5256 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:246: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000290691b5 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x0000000024735e3d 17. DB::ReadBuffer::next() @ 0x0000000018778250 18. ./src/IO/ReadHelpers.h:1832: DB::skipBOMIfExists(DB::ReadBuffer&) @ 0x00000000336c0912 19. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:79: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x00000000336b545d 20. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:103: DB::IRowInputFormat::read() @ 0x0000000033662a38 21. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 22. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 26. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 28. ./build_docker/./src/Storages/StorageURL.cpp:406: DB::StorageURLSource::generate() @ 0x00000000326594a1 29. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 2025.03.05 21:15:46.860099 [ 23577 ] {4cd70416-62b4-4077-be8c-c03282684230} TCPHandler: Client has gone away. 2025.03.05 21:15:47.057188 [ 1474 ] {a612df0e-22e3-4e4b-8963-9cda2566e028} executeQuery: Code: 57. DB::Exception: Table test_oyrg0zfq.none already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01175_distributed_ddl_output_mode_long.sh_01175_DDL_test_oyrg0zfq) (in query: /* ddl_entry=query-0000000094 */ CREATE TABLE test_oyrg0zfq.none UUID 'b0ce44ab-d1bc-4ba5-b9ee-125ce0dd3dee' (`n` Int32) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cf1bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:47.057446 [ 1474 ] {a612df0e-22e3-4e4b-8963-9cda2566e028} DDLWorker: Query /* ddl_entry=query-0000000094 */ CREATE TABLE test_oyrg0zfq.none UUID 'b0ce44ab-d1bc-4ba5-b9ee-125ce0dd3dee' (`n` Int32) ENGINE = Memory wasn't finished successfully: Code: 57. DB::Exception: Table test_oyrg0zfq.none already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cf1bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:47.103589 [ 730 ] {a5970f5b-c761-4641-8045-aad8c6edc58e} executeQuery: Code: 57. DB::Exception: There was an error on [localhost:9000]: Code: 57. DB::Exception: Table test_oyrg0zfq.none already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable). (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:38934) (comment: 01175_distributed_ddl_output_mode_long.sh_01175_DDL_test_oyrg0zfq) (in query: create table none on cluster test_shard_localhost (n int) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:47.103695 [ 730 ] {a5970f5b-c761-4641-8045-aad8c6edc58e} TCPHandler: Code: 57. DB::Exception: There was an error on [localhost:9000]: Code: 57. DB::Exception: Table test_oyrg0zfq.none already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:47.791637 [ 22860 ] {01168_mutations_isolation_test_nzqpr9gc_tx1_14960} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_5.txt' with part 'all_1_1_0' reason: 'Serialization error: part all_1_1_0 is locked by transaction 9742796126771737419'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:49982) (in query: alter table mt update n=n+1 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x000000003308621e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d657 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:47.791945 [ 22860 ] {01168_mutations_isolation_test_nzqpr9gc_tx1_14960} DynamicQueryHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_5.txt' with part 'all_1_1_0' reason: 'Serialization error: part all_1_1_0 is locked by transaction 9742796126771737419'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x000000003308621e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d657 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:47.818188 [ 48602 ] {01168_mutations_isolation_test_nzqpr9gc_tx1_1101} executeQuery: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:49996) (in query: commit), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:47.818441 [ 48602 ] {01168_mutations_isolation_test_nzqpr9gc_tx1_1101} DynamicQueryHandler: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:47.945173 [ 23610 ] {01168_mutations_isolation_test_nzqpr9gc_tx3_27445} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_9.txt' with part 'all_1_1_0' reason: 'Serialization error: part all_1_1_0 is locked by transaction 11396854832816511936'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50194) (in query: alter table mt update n=n+42 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x000000003308621e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d657 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:47.945453 [ 23610 ] {01168_mutations_isolation_test_nzqpr9gc_tx3_27445} DynamicQueryHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_9.txt' with part 'all_1_1_0' reason: 'Serialization error: part all_1_1_0 is locked by transaction 11396854832816511936'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x000000003308621e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d657 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:47.979821 [ 48611 ] {01168_mutations_isolation_test_nzqpr9gc_tx3_21549} executeQuery: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50214) (in query: insert into mt values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:888: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316ffc3f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:47.980101 [ 48611 ] {01168_mutations_isolation_test_nzqpr9gc_tx3_21549} DynamicQueryHandler: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:888: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316ffc3f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:48.012301 [ 48606 ] {01168_mutations_isolation_test_nzqpr9gc_tx3_19299} executeQuery: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50282) (in query: commit), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:48.012485 [ 48606 ] {01168_mutations_isolation_test_nzqpr9gc_tx3_19299} DynamicQueryHandler: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:48.080866 [ 22859 ] {01167_isolation_hermitage_test_8lyq5r6c_tx2_28225} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_4.txt' with part 'all_1_1_0' reason: 'Serialization error: part all_1_1_0 is locked by transaction 8108501345189563389'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50410) (in query: alter table test update value=12 where id=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x000000003308621e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d657 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:48.081094 [ 22859 ] {01167_isolation_hermitage_test_8lyq5r6c_tx2_28225} DynamicQueryHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_4.txt' with part 'all_1_1_0' reason: 'Serialization error: part all_1_1_0 is locked by transaction 8108501345189563389'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x000000003308621e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d657 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:48.151657 [ 22866 ] {01167_isolation_hermitage_test_8lyq5r6c_tx2_14223} executeQuery: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50530) (in query: alter table test update value=22 where id=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:888: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316ffc3f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:48.151893 [ 22866 ] {01167_isolation_hermitage_test_8lyq5r6c_tx2_14223} DynamicQueryHandler: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:888: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316ffc3f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:48.164895 [ 22866 ] {01167_isolation_hermitage_test_8lyq5r6c_tx2_1053} executeQuery: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50554) (in query: commit), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:48.165123 [ 22866 ] {01167_isolation_hermitage_test_8lyq5r6c_tx2_1053} DynamicQueryHandler: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:48.203709 [ 48606 ] {01168_mutations_isolation_test_nzqpr9gc_tx5_7732} executeQuery: Code: 650. DB::Exception: Serialization error: Transaction (114, 33, 17a9e4e3-6079-46b5-96d2-65b6c5db6991) tried to remove data part all_1_1_0_8 from test_nzqpr9gc.mt (4eab9331-8784-4182-bb52-0586449b05c8), but it's locked by another transaction (TID: (114, 41, 17a9e4e3-6079-46b5-96d2-65b6c5db6991), TIDH: 15933759750501107956) which is currently removing this part. (SERIALIZATION_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:50570) (in query: alter table mt drop partition id 'all'), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::TransactionID const&, String&, String&&, DB::TransactionID&&, unsigned long&) @ 0x00000000315ae19e 4. ./build_docker/./src/Interpreters/TransactionVersionMetadata.cpp:0: DB::VersionMetadata::lockRemovalTID(DB::TransactionID const&, DB::TransactionInfoContext const&) @ 0x00000000315aab99 5. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:0: DB::MergeTreeTransaction::removeOldPart(std::shared_ptr const&, std::shared_ptr const&, DB::TransactionInfoContext const&) @ 0x0000000031141039 6. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:93: DB::MergeTreeTransaction::removeOldPart(std::shared_ptr const&, std::shared_ptr const&, DB::MergeTreeTransaction*) @ 0x0000000031140c2f 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::removePartsFromWorkingSet(DB::MergeTreeTransaction*, std::vector, std::allocator>> const&, bool, DB::DataPartsLock&) @ 0x0000000032b591c1 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::dropPartition(std::shared_ptr const&, bool, std::shared_ptr) @ 0x00000000330b3a0d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5169: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032b8219e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307959bb 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 15. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:48.204003 [ 48606 ] {01168_mutations_isolation_test_nzqpr9gc_tx5_7732} DynamicQueryHandler: Code: 650. DB::Exception: Serialization error: Transaction (114, 33, 17a9e4e3-6079-46b5-96d2-65b6c5db6991) tried to remove data part all_1_1_0_8 from test_nzqpr9gc.mt (4eab9331-8784-4182-bb52-0586449b05c8), but it's locked by another transaction (TID: (114, 41, 17a9e4e3-6079-46b5-96d2-65b6c5db6991), TIDH: 15933759750501107956) which is currently removing this part. (SERIALIZATION_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::TransactionID const&, String&, String&&, DB::TransactionID&&, unsigned long&) @ 0x00000000315ae19e 4. ./build_docker/./src/Interpreters/TransactionVersionMetadata.cpp:0: DB::VersionMetadata::lockRemovalTID(DB::TransactionID const&, DB::TransactionInfoContext const&) @ 0x00000000315aab99 5. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:0: DB::MergeTreeTransaction::removeOldPart(std::shared_ptr const&, std::shared_ptr const&, DB::TransactionInfoContext const&) @ 0x0000000031141039 6. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:93: DB::MergeTreeTransaction::removeOldPart(std::shared_ptr const&, std::shared_ptr const&, DB::MergeTreeTransaction*) @ 0x0000000031140c2f 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::removePartsFromWorkingSet(DB::MergeTreeTransaction*, std::vector, std::allocator>> const&, bool, DB::DataPartsLock&) @ 0x0000000032b591c1 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::dropPartition(std::shared_ptr const&, bool, std::shared_ptr) @ 0x00000000330b3a0d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5169: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032b8219e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307959bb 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 15. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:48.421809 [ 23635 ] {8f047b8e-eb5f-45ec-ad5d-1fb0c9353f8b} executeQuery: Code: 159. DB::Exception: Distributed DDL task /clickhouse/task_queue/ddl/query-0000000095 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 1.108002319 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:39012) (comment: 01175_distributed_ddl_output_mode_long.sh_01175_DDL_test_oyrg0zfq) (in query: drop table if exists none on cluster test_unavailable_shard;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:48.421971 [ 23635 ] {8f047b8e-eb5f-45ec-ad5d-1fb0c9353f8b} TCPHandler: Code: 159. DB::Exception: Distributed DDL task /clickhouse/task_queue/ddl/query-0000000095 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 1.108002319 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:49.008478 [ 81468 ] {01168_mutations_isolation_test_nzqpr9gc_tx10_30582} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_16.txt' with part 'all_1_1_0_13' reason: 'Serialization error: part all_1_1_0_13 is locked by transaction 13588413266476804928'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:46686) (in query: alter table mt update n = 0 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x000000003308621e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d657 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:49.008820 [ 81468 ] {01168_mutations_isolation_test_nzqpr9gc_tx10_30582} DynamicQueryHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_16.txt' with part 'all_1_1_0_13' reason: 'Serialization error: part all_1_1_0_13 is locked by transaction 13588413266476804928'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x000000003308621e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d657 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:49.049617 [ 14974 ] {01168_mutations_isolation_test_nzqpr9gc_tx10_11444} executeQuery: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:46768) (in query: commit), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:49.049829 [ 14974 ] {01168_mutations_isolation_test_nzqpr9gc_tx10_11444} DynamicQueryHandler: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:49.219956 [ 1474 ] {5624e136-d8b3-4717-8694-e68f4867c405} executeQuery: Code: 57. DB::Exception: Table test_oyrg0zfq.throw already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01175_distributed_ddl_output_mode_long.sh_01175_DDL_test_oyrg0zfq) (in query: /* ddl_entry=query-0000000097 */ CREATE TABLE test_oyrg0zfq.throw UUID 'b2c29ca2-0ae0-45f6-a12f-bc1c5aa75c89' (`n` Int32) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cf1bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:49.220124 [ 1474 ] {5624e136-d8b3-4717-8694-e68f4867c405} DDLWorker: Query /* ddl_entry=query-0000000097 */ CREATE TABLE test_oyrg0zfq.throw UUID 'b2c29ca2-0ae0-45f6-a12f-bc1c5aa75c89' (`n` Int32) ENGINE = Memory wasn't finished successfully: Code: 57. DB::Exception: Table test_oyrg0zfq.throw already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cf1bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:49.270630 [ 48581 ] {4096fc95-c098-4a99-a733-4bc77b00f367} executeQuery: Code: 57. DB::Exception: There was an error on [localhost:9000]: Code: 57. DB::Exception: Table test_oyrg0zfq.throw already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable). (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:52858) (comment: 01175_distributed_ddl_output_mode_long.sh_01175_DDL_test_oyrg0zfq) (in query: create table throw on cluster test_shard_localhost (n int) engine=Memory format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:49.270725 [ 48581 ] {4096fc95-c098-4a99-a733-4bc77b00f367} TCPHandler: Code: 57. DB::Exception: There was an error on [localhost:9000]: Code: 57. DB::Exception: Table test_oyrg0zfq.throw already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:50.602182 [ 23562 ] {c8ccdfa4-a573-4f88-a87a-ab3f5047550e} executeQuery: Code: 159. DB::Exception: Distributed DDL task /clickhouse/task_queue/ddl/query-0000000098 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 1.108002317 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:52960) (comment: 01175_distributed_ddl_output_mode_long.sh_01175_DDL_test_oyrg0zfq) (in query: drop table if exists throw on cluster test_unavailable_shard;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:50.602289 [ 23562 ] {c8ccdfa4-a573-4f88-a87a-ab3f5047550e} TCPHandler: Code: 159. DB::Exception: Distributed DDL task /clickhouse/task_queue/ddl/query-0000000098 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 1.108002317 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x00000000316e865b 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:0: DB::DDLQueryStatusSource::generate() @ 0x00000000316df4e6 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:50.653769 [ 48602 ] {01168_mutations_isolation_test_nzqpr9gc_tx12_32167} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_19.txt' with part 'all_1_14_1_17' reason: 'Serialization error: part all_1_14_1_17 is locked by transaction 411561246207030589'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:48256) (in query: alter table mt update n=n+1 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x000000003308621e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d657 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:50.654011 [ 48602 ] {01168_mutations_isolation_test_nzqpr9gc_tx12_32167} DynamicQueryHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_19.txt' with part 'all_1_14_1_17' reason: 'Serialization error: part all_1_14_1_17 is locked by transaction 411561246207030589'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x000000003308621e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d657 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:51.350576 [ 1474 ] {7a26fb57-8b91-4eca-8b52-9ba9d5833f93} executeQuery: Code: 57. DB::Exception: Table test_oyrg0zfq.null_status already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01175_distributed_ddl_output_mode_long.sh_01175_DDL_test_oyrg0zfq) (in query: /* ddl_entry=query-0000000100 */ CREATE TABLE test_oyrg0zfq.null_status UUID '9c18713a-9981-45df-86d7-3b4faec42afd' (`n` Int32) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cf1bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:51.350713 [ 1474 ] {7a26fb57-8b91-4eca-8b52-9ba9d5833f93} DDLWorker: Query /* ddl_entry=query-0000000100 */ CREATE TABLE test_oyrg0zfq.null_status UUID '9c18713a-9981-45df-86d7-3b4faec42afd' (`n` Int32) ENGINE = Memory wasn't finished successfully: Code: 57. DB::Exception: Table test_oyrg0zfq.null_status already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cf1bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:51.400679 [ 23587 ] {2a2108a0-b541-4aa4-82ef-55ae41990256} executeQuery: Code: 57. DB::Exception: There was an error on [localhost:9000]: Code: 57. DB::Exception: Table test_oyrg0zfq.null_status already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable). (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:53700) (comment: 01175_distributed_ddl_output_mode_long.sh_01175_DDL_test_oyrg0zfq) (in query: create table null_status on cluster test_shard_localhost (n int) engine=Memory format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:51.400816 [ 23587 ] {2a2108a0-b541-4aa4-82ef-55ae41990256} TCPHandler: Code: 57. DB::Exception: There was an error on [localhost:9000]: Code: 57. DB::Exception: Table test_oyrg0zfq.null_status already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String&) @ 0x00000000316e8915 4. ./build_docker/./src/Interpreters/executeDDLQueryOnCluster.cpp:574: DB::DDLQueryStatusSource::generate() @ 0x00000000316ddc4f 5. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033571f31 12. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 14. ? @ 0x00007fe1df9bbac3 15. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:51.655350 [ 48614 ] {01168_mutations_isolation_test_nzqpr9gc_tx12_1458} executeQuery: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:48930) (in query: commit), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:51.655551 [ 48614 ] {01168_mutations_isolation_test_nzqpr9gc_tx12_1458} DynamicQueryHandler: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:51.784020 [ 6307 ] {a40e04bb-f745-43bd-89ba-16f42eec8e4c} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.6:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.6:8123'. Failed at try 10/10. 2025.03.05 21:15:51.784033 [ 5671 ] {a40e04bb-f745-43bd-89ba-16f42eec8e4c} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.8:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.8:8123'. Failed at try 10/10. 2025.03.05 21:15:51.784177 [ 1619 ] {a40e04bb-f745-43bd-89ba-16f42eec8e4c} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.9:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.9:8123'. Failed at try 10/10. 2025.03.05 21:15:51.788188 [ 1608 ] {a40e04bb-f745-43bd-89ba-16f42eec8e4c} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.7:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.7:8123'. Failed at try 10/10. 2025.03.05 21:15:51.792860 [ 11243 ] {a40e04bb-f745-43bd-89ba-16f42eec8e4c} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.4:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.4:8123'. Failed at try 10/10. 2025.03.05 21:15:51.807999 [ 11460 ] {a40e04bb-f745-43bd-89ba-16f42eec8e4c} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.10:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.10:8123'. Failed at try 10/10. 2025.03.05 21:15:51.822403 [ 34687 ] {a40e04bb-f745-43bd-89ba-16f42eec8e4c} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.2:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.2:8123'. Failed at try 10/10. 2025.03.05 21:15:51.831934 [ 34826 ] {a40e04bb-f745-43bd-89ba-16f42eec8e4c} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.5:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.5:8123'. Failed at try 10/10. 2025.03.05 21:15:51.832160 [ 11329 ] {a40e04bb-f745-43bd-89ba-16f42eec8e4c} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.3:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.3:8123'. Failed at try 10/10. 2025.03.05 21:15:51.834552 [ 11455 ] {a40e04bb-f745-43bd-89ba-16f42eec8e4c} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.1:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.1:8123'. Failed at try 10/10. 2025.03.05 21:15:51.838595 [ 22865 ] {a40e04bb-f745-43bd-89ba-16f42eec8e4c} executeQuery: Poco::Exception. Code: 1000, e.code() = 0, Timeout: connect timed out: 128.0.0.1:8123 (version 24.3.12.76.altinitystable) (from [::1]:43888) (comment: 02044_url_glob_parallel_connection_refused.sh) (in query: SELECT * FROM url('http://128.0.0.{1..10}:8123/?query=SELECT+sleep(1)', TSV, 'x UInt8')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:37: Poco::Exception::Exception(String const&, String const&, int) @ 0x000000003697aad2 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:148: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x0000000036981c9b 3. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000367ad1eb 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:214: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x000000003677648a 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:0: Poco::Net::HTTPClientSession::reconnect() @ 0x0000000036752c54 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c7216 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:540: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c51d9 8. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration) @ 0x0000000024ab5256 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:246: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000290691b5 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x0000000024735e3d 17. DB::ReadBuffer::next() @ 0x0000000018778250 18. ./src/IO/ReadHelpers.h:1832: DB::skipBOMIfExists(DB::ReadBuffer&) @ 0x00000000336c0912 19. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:79: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x00000000336b545d 20. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:103: DB::IRowInputFormat::read() @ 0x0000000033662a38 21. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 22. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 26. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 28. ./build_docker/./src/Storages/StorageURL.cpp:406: DB::StorageURLSource::generate() @ 0x00000000326594a1 29. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 2025.03.05 21:15:51.839630 [ 22865 ] {a40e04bb-f745-43bd-89ba-16f42eec8e4c} TCPHandler: Code: 1000. DB::Exception: Timeout: connect timed out: 128.0.0.1:8123. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:37: Poco::Exception::Exception(String const&, String const&, int) @ 0x000000003697aad2 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:148: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x0000000036981c9b 3. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000367ad1eb 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:214: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x000000003677648a 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:0: Poco::Net::HTTPClientSession::reconnect() @ 0x0000000036752c54 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c7216 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:540: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c51d9 8. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration) @ 0x0000000024ab5256 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:246: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000290691b5 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x0000000024735e3d 17. DB::ReadBuffer::next() @ 0x0000000018778250 18. ./src/IO/ReadHelpers.h:1832: DB::skipBOMIfExists(DB::ReadBuffer&) @ 0x00000000336c0912 19. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:79: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x00000000336b545d 20. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:103: DB::IRowInputFormat::read() @ 0x0000000033662a38 21. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 22. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 26. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 28. ./build_docker/./src/Storages/StorageURL.cpp:406: DB::StorageURLSource::generate() @ 0x00000000326594a1 29. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 2025.03.05 21:15:51.840025 [ 22865 ] {a40e04bb-f745-43bd-89ba-16f42eec8e4c} TCPHandler: Client has gone away. 2025.03.05 21:15:53.514741 [ 1474 ] {f1b401da-1687-4e59-920e-1663678c2319} executeQuery: Code: 57. DB::Exception: Table test_oyrg0zfq.never_throw already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from 0.0.0.0:0) (comment: 01175_distributed_ddl_output_mode_long.sh_01175_DDL_test_oyrg0zfq) (in query: /* ddl_entry=query-0000000103 */ CREATE TABLE test_oyrg0zfq.never_throw UUID '508bd09f-b43a-4110-9da7-714f84f49c2a' (`n` Int32) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cf1bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:53.514954 [ 1474 ] {f1b401da-1687-4e59-920e-1663678c2319} DDLWorker: Query /* ddl_entry=query-0000000103 */ CREATE TABLE test_oyrg0zfq.never_throw UUID '508bd09f-b43a-4110-9da7-714f84f49c2a' (`n` Int32) ENGINE = Memory wasn't finished successfully: Code: 57. DB::Exception: Table test_oyrg0zfq.never_throw already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cf1bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002fd621c0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002fd5ea1a 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002fd59f4c 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1149: DB::DDLWorker::runMainThread() @ 0x000000002fd4c680 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002fd7bfbd 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:54.903431 [ 48599 ] {71c6a410-800c-4bf4-aced-fe4474227d39} executeQuery: Code: 81. DB::Exception: Database INFORMATION_schema does not exist. Maybe you meant INFORMATION_SCHEMA?. (UNKNOWN_DATABASE) (version 24.3.12.76.altinitystable) (from [::1]:54816) (comment: 01161_information_schema.sql) (in query: SHOW TABLES FROM INFORMATION_schema;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002fd87f84 5. ./contrib/llvm-project/libcxx/include/string:1624: DB::InterpreterShowTablesQuery::getRewrittenQuery() @ 0x000000003177c0e6 6. ./build_docker/./src/Interpreters/InterpreterShowTablesQuery.cpp:218: DB::InterpreterShowTablesQuery::execute() @ 0x000000003177d423 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:54.903617 [ 48599 ] {71c6a410-800c-4bf4-aced-fe4474227d39} TCPHandler: Code: 81. DB::Exception: Database INFORMATION_schema does not exist. Maybe you meant INFORMATION_SCHEMA?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002fd87f84 5. ./contrib/llvm-project/libcxx/include/string:1624: DB::InterpreterShowTablesQuery::getRewrittenQuery() @ 0x000000003177c0e6 6. ./build_docker/./src/Interpreters/InterpreterShowTablesQuery.cpp:218: DB::InterpreterShowTablesQuery::execute() @ 0x000000003177d423 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:55.076022 [ 48599 ] {ae95581c-817d-43cc-9e6a-13f45bb5cb6a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'information_schema.taBLES' in scope SELECT count() FROM information_schema.taBLES WHERE (table_schema = currentDatabase()) AND (table_name = 't'). (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:54816) (comment: 01161_information_schema.sql) (in query: SELECT count() FROM information_schema.taBLES WHERE table_schema =currentDatabase() AND table_name = 't';), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:55.076256 [ 48599 ] {ae95581c-817d-43cc-9e6a-13f45bb5cb6a} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'information_schema.taBLES' in scope SELECT count() FROM information_schema.taBLES WHERE (table_schema = currentDatabase()) AND (table_name = 't'). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:56.612783 [ 64953 ] {503a4d5a-f14d-44c2-ae3c-11020f4b1187} executeQuery: Code: 43. DB::Exception: Nested type Array(String) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:55228) (comment: 01159_combinators_with_parameters.sql) (in query: SELECT toTypeName(topKOrNullState(10)(toString(number))) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:0: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x000000002f4db1df 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000] const&>(std::allocator, std::shared_ptr const&) @ 0x0000000028fc055c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr const&, void>(std::allocator const&, std::shared_ptr const&) @ 0x0000000028fc02c0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::AggregateFunctionOrFill::createResultType(std::shared_ptr const&) @ 0x0000000028fba6bd 8. ./src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:37: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028fb9fe1 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::AggregateFunctionOrFill* std::construct_at[abi:v15000], std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionOrFill*>(DB::AggregateFunctionOrFill*, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028fb9ed8 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:v15000] const&, std::vector, std::allocator>> const&, DB::Array const&>(std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028fb9986 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr> std::allocate_shared[abi:v15000], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028fb96ec 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028fb9602 13. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 14. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 15. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:248: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7d32 16. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 24. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 30. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 2025.03.05 21:15:56.613029 [ 64953 ] {503a4d5a-f14d-44c2-ae3c-11020f4b1187} TCPHandler: Code: 43. DB::Exception: Nested type Array(String) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:0: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x000000002f4db1df 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000] const&>(std::allocator, std::shared_ptr const&) @ 0x0000000028fc055c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], std::shared_ptr const&, void>(std::allocator const&, std::shared_ptr const&) @ 0x0000000028fc02c0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::AggregateFunctionOrFill::createResultType(std::shared_ptr const&) @ 0x0000000028fba6bd 8. ./src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:37: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028fb9fe1 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::AggregateFunctionOrFill* std::construct_at[abi:v15000], std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionOrFill*>(DB::AggregateFunctionOrFill*, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028fb9ed8 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:v15000] const&, std::vector, std::allocator>> const&, DB::Array const&>(std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028fb9986 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr> std::allocate_shared[abi:v15000], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028fb96ec 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028fb9602 13. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7db8 14. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 15. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:248: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002e8d7d32 16. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 21. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 24. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 25. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 30. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 2025.03.05 21:15:56.816914 [ 1674 ] {03468f8d-3d9c-4438-aa1c-48efa6f2ffb8} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.8:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.8:8123'. Failed at try 10/10. 2025.03.05 21:15:56.817042 [ 6332 ] {03468f8d-3d9c-4438-aa1c-48efa6f2ffb8} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.10:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.10:8123'. Failed at try 10/10. 2025.03.05 21:15:56.819994 [ 11348 ] {03468f8d-3d9c-4438-aa1c-48efa6f2ffb8} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.9:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.9:8123'. Failed at try 10/10. 2025.03.05 21:15:56.848336 [ 34700 ] {03468f8d-3d9c-4438-aa1c-48efa6f2ffb8} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.6:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.6:8123'. Failed at try 10/10. 2025.03.05 21:15:56.848861 [ 5997 ] {03468f8d-3d9c-4438-aa1c-48efa6f2ffb8} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.3:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.3:8123'. Failed at try 10/10. 2025.03.05 21:15:56.848861 [ 11383 ] {03468f8d-3d9c-4438-aa1c-48efa6f2ffb8} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.5:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.5:8123'. Failed at try 10/10. 2025.03.05 21:15:56.848925 [ 34832 ] {03468f8d-3d9c-4438-aa1c-48efa6f2ffb8} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.4:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.4:8123'. Failed at try 10/10. 2025.03.05 21:15:56.849136 [ 34892 ] {03468f8d-3d9c-4438-aa1c-48efa6f2ffb8} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.7:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.7:8123'. Failed at try 10/10. 2025.03.05 21:15:56.849688 [ 11415 ] {03468f8d-3d9c-4438-aa1c-48efa6f2ffb8} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.1:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.1:8123'. Failed at try 10/10. 2025.03.05 21:15:56.850284 [ 6276 ] {03468f8d-3d9c-4438-aa1c-48efa6f2ffb8} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.2:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.2:8123'. Failed at try 10/10. 2025.03.05 21:15:56.850861 [ 23601 ] {03468f8d-3d9c-4438-aa1c-48efa6f2ffb8} executeQuery: Poco::Exception. Code: 1000, e.code() = 0, Timeout: connect timed out: 128.0.0.1:8123 (version 24.3.12.76.altinitystable) (from [::1]:44552) (comment: 02044_url_glob_parallel_connection_refused.sh) (in query: SELECT * FROM url('http://128.0.0.{1..10}:8123/?query=SELECT+sleep(1)', TSV, 'x UInt8')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:37: Poco::Exception::Exception(String const&, String const&, int) @ 0x000000003697aad2 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:148: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x0000000036981c9b 3. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000367ad1eb 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:214: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x000000003677648a 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:0: Poco::Net::HTTPClientSession::reconnect() @ 0x0000000036752c54 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c7216 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:540: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c51d9 8. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration) @ 0x0000000024ab5256 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:246: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000290691b5 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x0000000024735e3d 17. DB::ReadBuffer::next() @ 0x0000000018778250 18. ./src/IO/ReadHelpers.h:1832: DB::skipBOMIfExists(DB::ReadBuffer&) @ 0x00000000336c0912 19. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:79: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x00000000336b545d 20. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:103: DB::IRowInputFormat::read() @ 0x0000000033662a38 21. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 22. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 26. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 28. ./build_docker/./src/Storages/StorageURL.cpp:406: DB::StorageURLSource::generate() @ 0x00000000326594a1 29. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 2025.03.05 21:15:56.852095 [ 23601 ] {03468f8d-3d9c-4438-aa1c-48efa6f2ffb8} TCPHandler: Code: 1000. DB::Exception: Timeout: connect timed out: 128.0.0.1:8123. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:37: Poco::Exception::Exception(String const&, String const&, int) @ 0x000000003697aad2 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:148: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x0000000036981c9b 3. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000367ad1eb 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:214: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x000000003677648a 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:0: Poco::Net::HTTPClientSession::reconnect() @ 0x0000000036752c54 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c7216 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:540: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c51d9 8. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration) @ 0x0000000024ab5256 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:246: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000290691b5 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x0000000024735e3d 17. DB::ReadBuffer::next() @ 0x0000000018778250 18. ./src/IO/ReadHelpers.h:1832: DB::skipBOMIfExists(DB::ReadBuffer&) @ 0x00000000336c0912 19. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:79: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x00000000336b545d 20. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:103: DB::IRowInputFormat::read() @ 0x0000000033662a38 21. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 22. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 26. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 28. ./build_docker/./src/Storages/StorageURL.cpp:406: DB::StorageURLSource::generate() @ 0x00000000326594a1 29. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 2025.03.05 21:15:56.852280 [ 23601 ] {03468f8d-3d9c-4438-aa1c-48efa6f2ffb8} TCPHandler: Client has gone away. 2025.03.05 21:15:57.172763 [ 1574 ] {1c93d515-b4e6-496e-9532-6b4d896e7311} DistributedSink: Structure does not match (remote: n UInt64 UInt64(size = 0), local: n Int32 Int32(size = 1)), implicit conversion will be done. 2025.03.05 21:15:57.367721 [ 1574 ] {5d48be2f-01ce-4788-96cc-58ad604eb149} StorageBuffer (test_hwvf607s._tmp_replace_ff70f6e747e7dcb4_4b05): Destination table test_hwvf607s.t have different type of column n (UInt64 != Int32). Block of data is converted. 2025.03.05 21:15:57.384527 [ 1574 ] {b4192ecf-bf78-413d-9b9d-48af059556f2} DistributedSink: Structure does not match (remote: n UInt64 UInt64(size = 0), local: n Int32 Int32(size = 1)), implicit conversion will be done. 2025.03.05 21:15:57.599351 [ 1574 ] {bff42d74-0363-4047-b2df-41764d98d99a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(__table1.n : 2) -> throwIf(__table1.n) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:55386) (comment: 01157_replace_table.sql) (in query: -- table is not created if select fails create or replace table join engine=Join(ANY, INNER, n) as select * from t where throwIf(n);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219ca44d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000033b59e3a 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:265: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000033b598fa 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:57.599653 [ 1574 ] {bff42d74-0363-4047-b2df-41764d98d99a} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(__table1.n : 2) -> throwIf(__table1.n) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219ca44d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000033b59e3a 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:265: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000033b598fa 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:57.679143 [ 1574 ] {d434c2bb-6dfa-4469-a1b5-028de2be8c69} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(__table1.n : 2) -> throwIf(__table1.n) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:55386) (comment: 01157_replace_table.sql) (in query: replace table join engine=Join(ANY, INNER, n) as select * from t where throwIf(n);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219ca44d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000033b59e3a 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:265: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000033b598fa 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:57.679399 [ 1574 ] {d434c2bb-6dfa-4469-a1b5-028de2be8c69} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(__table1.n : 2) -> throwIf(__table1.n) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219ca44d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000033b59e3a 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:265: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000033b598fa 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:59.948378 [ 48624 ] {01167_isolation_hermitage_test_8lyq5r6c_tx8_26649} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_17.txt' with part 'all_14_14_0' reason: 'Serialization error: part all_14_14_0 is locked by transaction 12316922091262123941'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:53760) (in query: alter table test update value=22 where id=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x000000003308621e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d657 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:59.948575 [ 48624 ] {01167_isolation_hermitage_test_8lyq5r6c_tx8_26649} DynamicQueryHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_17.txt' with part 'all_14_14_0' reason: 'Serialization error: part all_14_14_0 is locked by transaction 12316922091262123941'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x000000003308621e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d657 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:15:59.976128 [ 48624 ] {01167_isolation_hermitage_test_8lyq5r6c_tx8_23170} executeQuery: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:53786) (in query: select 9, * from test order by id), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:888: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316ffc3f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:15:59.976342 [ 48624 ] {01167_isolation_hermitage_test_8lyq5r6c_tx8_23170} DynamicQueryHandler: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:888: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316ffc3f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:00.003447 [ 48624 ] {01167_isolation_hermitage_test_8lyq5r6c_tx8_31297} executeQuery: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:53792) (in query: commit), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:00.003616 [ 48624 ] {01167_isolation_hermitage_test_8lyq5r6c_tx8_31297} DynamicQueryHandler: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:00.374542 [ 81478 ] {df2dad91-8685-4ead-9c74-036663df8bba} executeQuery: Code: 16. DB::Exception: StorageJoin doesn't contain column : In scope SELECT joinGet('t1', '', number) FROM numbers(2). (NO_SUCH_COLUMN_IN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:37042) (comment: 01141_join_get_negative.sql) (in query: SELECT joinGet('t1', '', number) FROM numbers(2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/HashJoin.cpp:1964: DB::HashJoin::joinGetCheckAndGetReturnType(std::vector, std::allocator>> const&, String const&, bool) const @ 0x00000000303f7cc5 5. DB::(anonymous namespace)::JoinGetOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x00000000180887e4 6. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844964 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:00.374709 [ 81478 ] {df2dad91-8685-4ead-9c74-036663df8bba} TCPHandler: Code: 16. DB::Exception: StorageJoin doesn't contain column : In scope SELECT joinGet('t1', '', number) FROM numbers(2). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/HashJoin.cpp:1964: DB::HashJoin::joinGetCheckAndGetReturnType(std::vector, std::allocator>> const&, String const&, bool) const @ 0x00000000303f7cc5 5. DB::(anonymous namespace)::JoinGetOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x00000000180887e4 6. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844964 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:00.400305 [ 81478 ] {4fe8542a-adb5-4f0e-8c5b-80dc36ce4a42} executeQuery: Code: 264. DB::Exception: joinGet only supports StorageJoin of type Left Any. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.3.12.76.altinitystable) (from [::1]:37042) (comment: 01141_join_get_negative.sql) (in query: SELECT joinGet('t2', 's', number) FROM numbers(2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/HashJoin.cpp:1979: DB::HashJoin::joinGet(DB::Block const&, DB::Block const&) const @ 0x00000000303f8716 5. ./build_docker/./src/Storages/StorageJoin.cpp:294: DB::StorageJoin::joinGet(DB::Block const&, DB::Block const&, std::shared_ptr) const @ 0x000000003224b9dd 6. DB::(anonymous namespace)::ExecutableFunctionJoinGet::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001808e8b7 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 13. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 15. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:00.400481 [ 81478 ] {4fe8542a-adb5-4f0e-8c5b-80dc36ce4a42} TCPHandler: Code: 264. DB::Exception: joinGet only supports StorageJoin of type Left Any. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/HashJoin.cpp:1979: DB::HashJoin::joinGet(DB::Block const&, DB::Block const&) const @ 0x00000000303f8716 5. ./build_docker/./src/Storages/StorageJoin.cpp:294: DB::StorageJoin::joinGet(DB::Block const&, DB::Block const&, std::shared_ptr) const @ 0x000000003224b9dd 6. DB::(anonymous namespace)::ExecutableFunctionJoinGet::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001808e8b7 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180940df 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840943 10. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 13. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 15. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:01.314668 [ 81471 ] {b44e8697-c298-492a-b677-6916af428d02} executeQuery: Code: 191. DB::Exception: Limit for IN-set exceeded, max rows: 20.00, current rows: 21.00: While executing CreatingSetsTransform. (SET_SIZE_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:37432) (comment: 01134_set_overflow_mode.sql) (in query: SELECT arrayJoin([5, 25]) IN (SELECT DISTINCT toUInt8(intDiv(number, 10)) FROM numbers(300));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, DB::SetKeyColumns&) @ 0x00000000313545d8 6. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x0000000031353682 7. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromBlock(std::vector> const&) @ 0x00000000313533b6 8. ./build_docker/./src/Processors/Transforms/CreatingSetsTransform.cpp:215: DB::CreatingSetsTransform::consume(DB::Chunk) @ 0x0000000033b31c3d 9. ./build_docker/./src/Processors/IAccumulatingTransform.cpp:0: DB::IAccumulatingTransform::work() @ 0x0000000033537b75 10. ./build_docker/./src/Processors/Transforms/CreatingSetsTransform.cpp:102: DB::CreatingSetsTransform::work() @ 0x0000000033b294a1 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:01.315319 [ 81471 ] {b44e8697-c298-492a-b677-6916af428d02} TCPHandler: Code: 191. DB::Exception: Limit for IN-set exceeded, max rows: 20.00, current rows: 21.00: While executing CreatingSetsTransform. (SET_SIZE_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, DB::SetKeyColumns&) @ 0x00000000313545d8 6. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x0000000031353682 7. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromBlock(std::vector> const&) @ 0x00000000313533b6 8. ./build_docker/./src/Processors/Transforms/CreatingSetsTransform.cpp:215: DB::CreatingSetsTransform::consume(DB::Chunk) @ 0x0000000033b31c3d 9. ./build_docker/./src/Processors/IAccumulatingTransform.cpp:0: DB::IAccumulatingTransform::work() @ 0x0000000033537b75 10. ./build_docker/./src/Processors/Transforms/CreatingSetsTransform.cpp:102: DB::CreatingSetsTransform::work() @ 0x0000000033b294a1 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:01.334088 [ 81478 ] {01167_isolation_hermitage_test_8lyq5r6c_tx10_29561} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_22.txt' with part 'all_18_18_0' reason: 'Serialization error: part all_18_18_0 is locked by transaction 10950011405216818372'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:53864) (in query: alter table test update value = 12 where id = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x000000003308621e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d657 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:01.334296 [ 81478 ] {01167_isolation_hermitage_test_8lyq5r6c_tx10_29561} DynamicQueryHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_22.txt' with part 'all_18_18_0' reason: 'Serialization error: part all_18_18_0 is locked by transaction 10950011405216818372'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x000000003308621e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d657 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:01.378650 [ 81471 ] {c1d5f6f4-4a5d-4fa4-95cd-13cc542887a2} executeQuery: Code: 191. DB::Exception: Limit for IN-set exceeded, max rows: 20.00, current rows: 21.00: While executing CreatingSetsTransform. (SET_SIZE_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:37432) (comment: 01134_set_overflow_mode.sql) (in query: SELECT arrayJoin([5, 25]) IN (SELECT DISTINCT toUInt8(intDiv(number, 10)) FROM numbers(210));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, DB::SetKeyColumns&) @ 0x00000000313545d8 6. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x0000000031353682 7. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromBlock(std::vector> const&) @ 0x00000000313533b6 8. ./build_docker/./src/Processors/Transforms/CreatingSetsTransform.cpp:215: DB::CreatingSetsTransform::consume(DB::Chunk) @ 0x0000000033b31c3d 9. ./build_docker/./src/Processors/IAccumulatingTransform.cpp:0: DB::IAccumulatingTransform::work() @ 0x0000000033537b75 10. ./build_docker/./src/Processors/Transforms/CreatingSetsTransform.cpp:102: DB::CreatingSetsTransform::work() @ 0x0000000033b294a1 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:01.378875 [ 81471 ] {c1d5f6f4-4a5d-4fa4-95cd-13cc542887a2} TCPHandler: Code: 191. DB::Exception: Limit for IN-set exceeded, max rows: 20.00, current rows: 21.00: While executing CreatingSetsTransform. (SET_SIZE_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, DB::SetKeyColumns&) @ 0x00000000313545d8 6. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x0000000031353682 7. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromBlock(std::vector> const&) @ 0x00000000313533b6 8. ./build_docker/./src/Processors/Transforms/CreatingSetsTransform.cpp:215: DB::CreatingSetsTransform::consume(DB::Chunk) @ 0x0000000033b31c3d 9. ./build_docker/./src/Processors/IAccumulatingTransform.cpp:0: DB::IAccumulatingTransform::work() @ 0x0000000033537b75 10. ./build_docker/./src/Processors/Transforms/CreatingSetsTransform.cpp:102: DB::CreatingSetsTransform::work() @ 0x0000000033b294a1 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 14. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 15. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 16. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:01.381503 [ 81478 ] {01167_isolation_hermitage_test_8lyq5r6c_tx10_6319} executeQuery: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:53892) (in query: alter table test update value = 18 where id = 2), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:888: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316ffc3f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:01.381669 [ 81478 ] {01167_isolation_hermitage_test_8lyq5r6c_tx10_6319} DynamicQueryHandler: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:888: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316ffc3f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:01.411262 [ 81478 ] {01167_isolation_hermitage_test_8lyq5r6c_tx10_5775} executeQuery: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:53916) (in query: commit), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:01.411430 [ 81478 ] {01167_isolation_hermitage_test_8lyq5r6c_tx10_5775} DynamicQueryHandler: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:01.654798 [ 48581 ] {90343965-75ea-4cbe-898d-2b6583d95460} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 30.00. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:37522) (comment: 01132_max_rows_to_read.sql) (in query: SELECT count() FROM numbers(30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:624: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x0000000033fdc5dd 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:549: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000033fda3b6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033fd8140 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:01.655060 [ 48581 ] {90343965-75ea-4cbe-898d-2b6583d95460} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 30.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:624: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x0000000033fdc5dd 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:549: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000033fda3b6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033fd8140 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:01.686627 [ 48581 ] {e01db42a-f2e8-4dc0-923a-11b02d3e2c28} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 21.00. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:37522) (comment: 01132_max_rows_to_read.sql) (in query: SELECT count() FROM numbers(21);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:624: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x0000000033fdc5dd 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:549: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000033fda3b6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033fd8140 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:01.686837 [ 48581 ] {e01db42a-f2e8-4dc0-923a-11b02d3e2c28} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 21.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:624: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x0000000033fdc5dd 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:549: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000033fda3b6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033fd8140 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:01.690306 [ 48581 ] {94832f71-e148-454f-8e92-d77226da71a0} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 30.00. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:37522) (comment: 01132_max_rows_to_read.sql) (in query: -- check early exception if the estimated number of rows is high SELECT * FROM numbers(30);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:624: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x0000000033fdc5dd 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:549: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000033fda3b6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033fd8140 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:01.690483 [ 48581 ] {94832f71-e148-454f-8e92-d77226da71a0} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 30.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:624: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x0000000033fdc5dd 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:549: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000033fda3b6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033fd8140 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:01.919716 [ 1844 ] {d59f2823-d2d3-4bec-8210-3198777d6ca1} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.4:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.4:8123'. Failed at try 10/10. 2025.03.05 21:16:01.920100 [ 6310 ] {d59f2823-d2d3-4bec-8210-3198777d6ca1} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.2:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.2:8123'. Failed at try 10/10. 2025.03.05 21:16:01.921035 [ 11449 ] {d59f2823-d2d3-4bec-8210-3198777d6ca1} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.1:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.1:8123'. Failed at try 10/10. 2025.03.05 21:16:01.922114 [ 34884 ] {d59f2823-d2d3-4bec-8210-3198777d6ca1} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.8:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.8:8123'. Failed at try 10/10. 2025.03.05 21:16:01.923607 [ 34736 ] {d59f2823-d2d3-4bec-8210-3198777d6ca1} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.6:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.6:8123'. Failed at try 10/10. 2025.03.05 21:16:01.928397 [ 34838 ] {d59f2823-d2d3-4bec-8210-3198777d6ca1} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.7:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.7:8123'. Failed at try 10/10. 2025.03.05 21:16:01.928823 [ 34740 ] {d59f2823-d2d3-4bec-8210-3198777d6ca1} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.3:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.3:8123'. Failed at try 10/10. 2025.03.05 21:16:01.928892 [ 6375 ] {d59f2823-d2d3-4bec-8210-3198777d6ca1} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.5:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.5:8123'. Failed at try 10/10. 2025.03.05 21:16:01.930220 [ 5816 ] {d59f2823-d2d3-4bec-8210-3198777d6ca1} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.9:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.9:8123'. Failed at try 10/10. 2025.03.05 21:16:01.934396 [ 11469 ] {d59f2823-d2d3-4bec-8210-3198777d6ca1} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.10:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.10:8123'. Failed at try 10/10. 2025.03.05 21:16:01.935243 [ 14973 ] {d59f2823-d2d3-4bec-8210-3198777d6ca1} executeQuery: Poco::Exception. Code: 1000, e.code() = 0, Timeout: connect timed out: 128.0.0.1:8123 (version 24.3.12.76.altinitystable) (from [::1]:41154) (comment: 02044_url_glob_parallel_connection_refused.sh) (in query: SELECT * FROM url('http://128.0.0.{1..10}:8123/?query=SELECT+sleep(1)', TSV, 'x UInt8')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:37: Poco::Exception::Exception(String const&, String const&, int) @ 0x000000003697aad2 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:148: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x0000000036981c9b 3. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000367ad1eb 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:214: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x000000003677648a 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:0: Poco::Net::HTTPClientSession::reconnect() @ 0x0000000036752c54 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c7216 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:540: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c51d9 8. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration) @ 0x0000000024ab5256 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:246: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000290691b5 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x0000000024735e3d 17. DB::ReadBuffer::next() @ 0x0000000018778250 18. ./src/IO/ReadHelpers.h:1832: DB::skipBOMIfExists(DB::ReadBuffer&) @ 0x00000000336c0912 19. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:79: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x00000000336b545d 20. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:103: DB::IRowInputFormat::read() @ 0x0000000033662a38 21. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 22. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 26. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 28. ./build_docker/./src/Storages/StorageURL.cpp:406: DB::StorageURLSource::generate() @ 0x00000000326594a1 29. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 2025.03.05 21:16:01.936237 [ 14973 ] {d59f2823-d2d3-4bec-8210-3198777d6ca1} TCPHandler: Code: 1000. DB::Exception: Timeout: connect timed out: 128.0.0.1:8123. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:37: Poco::Exception::Exception(String const&, String const&, int) @ 0x000000003697aad2 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:148: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x0000000036981c9b 3. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000367ad1eb 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:214: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x000000003677648a 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:0: Poco::Net::HTTPClientSession::reconnect() @ 0x0000000036752c54 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c7216 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:540: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c51d9 8. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration) @ 0x0000000024ab5256 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:246: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000290691b5 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x0000000024735e3d 17. DB::ReadBuffer::next() @ 0x0000000018778250 18. ./src/IO/ReadHelpers.h:1832: DB::skipBOMIfExists(DB::ReadBuffer&) @ 0x00000000336c0912 19. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:79: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x00000000336b545d 20. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:103: DB::IRowInputFormat::read() @ 0x0000000033662a38 21. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 22. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 26. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 28. ./build_docker/./src/Storages/StorageURL.cpp:406: DB::StorageURLSource::generate() @ 0x00000000326594a1 29. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 2025.03.05 21:16:01.936430 [ 14973 ] {d59f2823-d2d3-4bec-8210-3198777d6ca1} TCPHandler: Client has gone away. 2025.03.05 21:16:03.388580 [ 48598 ] {10812d84-6653-44a1-a953-2e9f00785eea} executeQuery: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statement with subquery may be nondeterministic, see allow_nondeterministic_mutations setting. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:38134) (comment: 01162_strange_mutations.sh) (in query: ALTER TABLE test UPDATE test = (SELECT groupArray(id) FROM t1 GROUP BY 'dummy')[n - 99] WHERE 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::validate() @ 0x00000000311621eb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795724 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:03.389039 [ 48598 ] {10812d84-6653-44a1-a953-2e9f00785eea} TCPHandler: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statement with subquery may be nondeterministic, see allow_nondeterministic_mutations setting. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::validate() @ 0x00000000311621eb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795724 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:03.442524 [ 14920 ] {f748f090-8c0a-4fad-88b6-ba1eab238675} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 6.00, current rows: 10.00. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:38122) (comment: 01114_materialize_clear_index_compact_parts.sql) (in query: SELECT count() FROM minmax_compact WHERE i64 = 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:257: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f496ac 6. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:03.442668 [ 14920 ] {f748f090-8c0a-4fad-88b6-ba1eab238675} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 6.00, current rows: 10.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:257: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f496ac 6. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:03.760344 [ 23639 ] {65cd9a93-bbc9-43e8-9971-11f4c3e19f26} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 76.37 MiB (attempt to allocate chunk of 80077548 bytes), maximum: 15.26 MiB. (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:38298) (comment: 01109_inflating_cross_join.sql) (in query: SELECT count(*) FROM numbers(10000) n1 CROSS JOIN numbers(1000) n2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000002461ef1f 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000018062b29 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::HashJoin::joinBlockImplCross(DB::Block&, std::shared_ptr&) const @ 0x00000000303f60d1 10. ./build_docker/./src/Interpreters/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x00000000303f8d99 11. ./contrib/llvm-project/libcxx/include/string:843: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000033b5e26a 12. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x0000000033ef2899 13. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x0000000033ef045c 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1455: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106d192 15. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 16. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:03.760610 [ 23639 ] {65cd9a93-bbc9-43e8-9971-11f4c3e19f26} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 76.37 MiB (attempt to allocate chunk of 80077548 bytes), maximum: 15.26 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000002461ef1f 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000018062b29 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::HashJoin::joinBlockImplCross(DB::Block&, std::shared_ptr&) const @ 0x00000000303f60d1 10. ./build_docker/./src/Interpreters/HashJoin.cpp:0: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x00000000303f8d99 11. ./contrib/llvm-project/libcxx/include/string:843: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000033b5e26a 12. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:104: DB::JoinStep::updateOutputStream() @ 0x0000000033ef2899 13. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:0: DB::JoinStep::JoinStep(DB::DataStream const&, DB::DataStream const&, std::shared_ptr, unsigned long, unsigned long, bool) @ 0x0000000033ef045c 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1455: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106d192 15. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 16. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:03.827529 [ 23586 ] {207df589-871f-48c6-9df9-287a8ec1483c} executeQuery: Code: 659. DB::Exception: Connection lost on attempt to commit transaction (316, 35, 17a9e4e3-6079-46b5-96d2-65b6c5db6991), will finalize it later: Fault injected (after commit). (UNKNOWN_STATUS_OF_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::1]:38326) (comment: 01133_begin_commit_race.sh) (in query: COMMIT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::TransactionID const&, String const&) @ 0x00000000315a34bb 4. ./build_docker/./src/Interpreters/TransactionLog.cpp:431: DB::TransactionLog::commitTransaction(std::shared_ptr const&, bool) @ 0x00000000315a1a64 5. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:0: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x00000000317181a6 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:03.827909 [ 23586 ] {207df589-871f-48c6-9df9-287a8ec1483c} TCPHandler: Code: 659. DB::Exception: Connection lost on attempt to commit transaction (316, 35, 17a9e4e3-6079-46b5-96d2-65b6c5db6991), will finalize it later: Fault injected (after commit). (UNKNOWN_STATUS_OF_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::TransactionID const&, String const&) @ 0x00000000315a34bb 4. ./build_docker/./src/Interpreters/TransactionLog.cpp:431: DB::TransactionLog::commitTransaction(std::shared_ptr const&, bool) @ 0x00000000315a1a64 5. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:0: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x00000000317181a6 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.140308 [ 6310 ] {3d9f807e-0d40-41e2-a4cd-f6dee7e3492e} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) 2025.03.05 21:16:05.140484 [ 6310 ] {3d9f807e-0d40-41e2-a4cd-f6dee7e3492e} ConnectionPoolWithFailover: Connection failed at try â„–2, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) 2025.03.05 21:16:05.140684 [ 6310 ] {3d9f807e-0d40-41e2-a4cd-f6dee7e3492e} ConnectionPoolWithFailover: Connection failed at try â„–3, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) 2025.03.05 21:16:05.141027 [ 11427 ] {3d9f807e-0d40-41e2-a4cd-f6dee7e3492e} ConnectionPoolWithFailover: There is no table `test_yocuzpsp`.`local_01099_b` on server: 127.0.0.1:9000 2025.03.05 21:16:05.141603 [ 34806 ] {3d9f807e-0d40-41e2-a4cd-f6dee7e3492e} ConnectionPoolWithFailover: There is no table `test_yocuzpsp`.`local_01099_b` on server: 127.0.0.2:9000 2025.03.05 21:16:05.142033 [ 23639 ] {3d9f807e-0d40-41e2-a4cd-f6dee7e3492e} StorageDistributed (distributed_01099_b): Cannot flush: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_yocuzpsp`.`local_01099_b` on server: 127.0.0.2:9000 : While sending /var/lib/clickhouse/store/294/294041e8-c11f-4ca9-bb42-9a51202b943e/shard1_replica2/2.bin. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000326ba9ec 4. ./src/Common/PoolWithFailoverBase.h:0: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x00000000332a91ad 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:223: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000332a45d2 6. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:170: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000332a4e02 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x000000003290e3d2 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:377: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x0000000032906db9 9. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000032906b09 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e722c80 11. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000295508e1 12. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 13. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:05.162847 [ 23639 ] {f44cf010-b743-4e00-ae14-bad64e1a2ce0} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) 2025.03.05 21:16:05.189023 [ 48606 ] {2830c49c-8156-4ff6-9b92-22c55c615828} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_tmog7hsv.join, because some tables depend on it: test_tmog7hsv.t (81f806c8-c744-48a8-b804-ef2707dff93e), test_tmog7hsv.s, test_tmog7hsv.dict2. (HAVE_DEPENDENT_OBJECTS) (version 24.3.12.76.altinitystable) (from [::1]:38938) (comment: 01160_table_dependencies.sh) (in query: rename table join to join1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000002fda7392 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1456: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9b344 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1416: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x000000002fd9aeea 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:138: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f4720b 7. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.189283 [ 48606 ] {2830c49c-8156-4ff6-9b92-22c55c615828} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_tmog7hsv.join, because some tables depend on it: test_tmog7hsv.t (81f806c8-c744-48a8-b804-ef2707dff93e), test_tmog7hsv.s, test_tmog7hsv.dict2. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000002fda7392 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1456: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9b344 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1416: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x000000002fd9aeea 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:138: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f4720b 7. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.236473 [ 11487 ] {fa4c5eb4-eba5-4f50-93d3-7370efa6ecf1} ConnectionPoolWithFailover: There is no table `test_yocuzpsp`.`local_01099_b` on server: 127.0.0.2:9000 2025.03.05 21:16:05.236479 [ 11228 ] {fa4c5eb4-eba5-4f50-93d3-7370efa6ecf1} ConnectionPoolWithFailover: There is no table `test_yocuzpsp`.`local_01099_b` on server: 127.0.0.1:9000 2025.03.05 21:16:05.236932 [ 1876 ] {fa4c5eb4-eba5-4f50-93d3-7370efa6ecf1} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) 2025.03.05 21:16:05.237198 [ 1876 ] {fa4c5eb4-eba5-4f50-93d3-7370efa6ecf1} ConnectionPoolWithFailover: Connection failed at try â„–2, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) 2025.03.05 21:16:05.237437 [ 1876 ] {fa4c5eb4-eba5-4f50-93d3-7370efa6ecf1} ConnectionPoolWithFailover: Connection failed at try â„–3, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) 2025.03.05 21:16:05.238050 [ 23639 ] {fa4c5eb4-eba5-4f50-93d3-7370efa6ecf1} StorageDistributed (distributed_01099_b): Cannot flush: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_yocuzpsp`.`local_01099_b` on server: 127.0.0.2:9000 : While sending /var/lib/clickhouse/store/45e/45e7537c-11b0-4dd3-b9a0-87e409c60319/shard1_replica2/2.bin. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000326ba9ec 4. ./src/Common/PoolWithFailoverBase.h:0: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x00000000332a91ad 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:223: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x00000000332a45d2 6. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:170: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x00000000332a4e02 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x000000003290e3d2 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:377: DB::DistributedAsyncInsertDirectoryQueue::processFiles(DB::SettingsChanges const&) @ 0x0000000032906db9 9. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x0000000032906b09 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e722c80 11. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000295508e1 12. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 13. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 14. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:05.448601 [ 5338 ] {1b76a7fa-592c-4fd6-83f6-68ea5453eda6} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_tmog7hsv.join (d57ff3f8-b84f-4aec-9dab-d58d8076b558), because some tables depend on it: test_tmog7hsv.t (81f806c8-c744-48a8-b804-ef2707dff93e), test_tmog7hsv.s, test_tmog7hsv.dict2. (HAVE_DEPENDENT_OBJECTS) (version 24.3.12.76.altinitystable) (from [::1]:39052) (comment: 01160_table_dependencies.sh) (in query: drop table join), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000002fda7392 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1456: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9b344 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9ba54 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000307f634b 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:103: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000307f3e26 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000307f29e2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.449371 [ 5338 ] {1b76a7fa-592c-4fd6-83f6-68ea5453eda6} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_tmog7hsv.join (d57ff3f8-b84f-4aec-9dab-d58d8076b558), because some tables depend on it: test_tmog7hsv.t (81f806c8-c744-48a8-b804-ef2707dff93e), test_tmog7hsv.s, test_tmog7hsv.dict2. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000002fda7392 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1456: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9b344 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9ba54 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000307f634b 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:103: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000307f3e26 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000307f29e2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.600346 [ 23628 ] {e27a5ace-1f93-4cdb-9320-53980ac55e82} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39090) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.600626 [ 23628 ] {e27a5ace-1f93-4cdb-9320-53980ac55e82} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.669383 [ 23610 ] {58a635f5-d87e-48b8-bfc6-e00deadcca89} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39128) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.670263 [ 23610 ] {58a635f5-d87e-48b8-bfc6-e00deadcca89} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.769111 [ 22858 ] {44e8290f-0ae7-49e5-88cc-85ac6e0628f3} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_tmog7hsv.dict1 (d88cf27f-50ad-4787-8231-daef41921e90), because some tables depend on it: test_tmog7hsv.t (81f806c8-c744-48a8-b804-ef2707dff93e), test_tmog7hsv.join. (HAVE_DEPENDENT_OBJECTS) (version 24.3.12.76.altinitystable) (from [::1]:39200) (comment: 01160_table_dependencies.sh) (in query: detach dictionary dict1 permanently), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000002fda7392 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1456: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9b344 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1416: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x000000002fd9aeea 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000307f67af 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:103: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000307f3e26 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000307f29e2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.803945 [ 5338 ] {0b66d1a5-8aaf-4799-a7e3-c150ffc562ff} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39212) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.804323 [ 5338 ] {0b66d1a5-8aaf-4799-a7e3-c150ffc562ff} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.804477 [ 22858 ] {44e8290f-0ae7-49e5-88cc-85ac6e0628f3} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_tmog7hsv.dict1 (d88cf27f-50ad-4787-8231-daef41921e90), because some tables depend on it: test_tmog7hsv.t (81f806c8-c744-48a8-b804-ef2707dff93e), test_tmog7hsv.join. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000002fda7392 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1456: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9b344 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1416: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x000000002fd9aeea 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000307f67af 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:103: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000307f3e26 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x00000000307f29e2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.804624 [ 22865 ] {2d8ae182-4fad-4f89-86b8-b06064d5130b} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39220) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.804984 [ 22865 ] {2d8ae182-4fad-4f89-86b8-b06064d5130b} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.838795 [ 48599 ] {c2202d19-645d-4104-99aa-a7d71e207e6c} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:39232) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.838851 [ 22866 ] {1b447ebf-abc2-4a32-9e06-006d69b4ecdc} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39244) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.839260 [ 22866 ] {1b447ebf-abc2-4a32-9e06-006d69b4ecdc} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.839435 [ 23587 ] {3b805a48-a06f-4b34-b0d2-4f9df4a30fff} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39248) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.839501 [ 23628 ] {f1957656-9e11-44dd-9b60-c8ef689b05b7} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:39138) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.839676 [ 23587 ] {3b805a48-a06f-4b34-b0d2-4f9df4a30fff} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.840751 [ 48599 ] {c2202d19-645d-4104-99aa-a7d71e207e6c} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.841395 [ 23628 ] {f1957656-9e11-44dd-9b60-c8ef689b05b7} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.864157 [ 5338 ] {3fb51eb2-fecb-4876-a9d8-dc227663a4c4} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:39256) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:05.864459 [ 5338 ] {3fb51eb2-fecb-4876-a9d8-dc227663a4c4} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.591246 [ 48603 ] {01167_isolation_hermitage_test_8lyq5r6c_tx15_157} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_29.txt' with part 'all_26_26_0' reason: 'Serialization error: part all_26_26_0 is locked by transaction 6224459232478782543'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:54022) (in query: alter table test delete where value = 20), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x000000003308621e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d657 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.591449 [ 48603 ] {01167_isolation_hermitage_test_8lyq5r6c_tx15_157} DynamicQueryHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_29.txt' with part 'all_26_26_0' reason: 'Serialization error: part all_26_26_0 is locked by transaction 6224459232478782543'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x000000003308621e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d657 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:06.632167 [ 1161 ] {} test_ztc1o1yj.concurrent_optimize_table (e1fa1231-34ae-4b4c-89a2-c7f16a5c02ba): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3522: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000032459618 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f0fe371 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002f103012 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002f103e52 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:06.632210 [ 48603 ] {01167_isolation_hermitage_test_8lyq5r6c_tx15_4953} executeQuery: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:54042) (in query: select 17, * from test order by id), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:888: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316ffc3f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.655429 [ 48603 ] {01167_isolation_hermitage_test_8lyq5r6c_tx15_4953} DynamicQueryHandler: Code: 649. DB::Exception: Cannot execute query because current transaction failed. Expecting ROLLBACK statement. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:888: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316ffc3f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 7. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:06.657181 [ 22865 ] {613dd005-2882-4072-9ea4-65541837f33e} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:39558) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033013e19 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.657348 [ 23587 ] {38a37bcc-c4d8-417d-abf7-a5c5851ff561} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:39590) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.657402 [ 23601 ] {c4b00062-603c-4f54-994d-d198b84d8b09} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:39604) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.659183 [ 23587 ] {38a37bcc-c4d8-417d-abf7-a5c5851ff561} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.659298 [ 23601 ] {c4b00062-603c-4f54-994d-d198b84d8b09} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.660404 [ 22865 ] {613dd005-2882-4072-9ea4-65541837f33e} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:0: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033013e19 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.674440 [ 48603 ] {01167_isolation_hermitage_test_8lyq5r6c_tx15_17445} executeQuery: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:54056) (in query: commit), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.674615 [ 48603 ] {01167_isolation_hermitage_test_8lyq5r6c_tx15_17445} DynamicQueryHandler: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:06.878112 [ 48631 ] {cb0c85fe-07c1-4f9a-a111-dc11ecc6f630} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:39736) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.880195 [ 48631 ] {cb0c85fe-07c1-4f9a-a111-dc11ecc6f630} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.884924 [ 23601 ] {59ab8c1b-4a8b-40d5-aad0-5fec029717f1} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39756) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.885295 [ 23601 ] {59ab8c1b-4a8b-40d5-aad0-5fec029717f1} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.898746 [ 1574 ] {f5db2473-ff58-4f7e-bde2-0ffbe607b899} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39778) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.899020 [ 1574 ] {f5db2473-ff58-4f7e-bde2-0ffbe607b899} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.906809 [ 34722 ] {20dacfd5-d11f-43d0-b6f5-77fd38602331} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.8:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.8:8123'. Failed at try 10/10. 2025.03.05 21:16:06.914696 [ 48631 ] {dc920022-f533-4fd0-92f5-8bf8c9500a28} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39782) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.914981 [ 48631 ] {dc920022-f533-4fd0-92f5-8bf8c9500a28} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.915970 [ 34701 ] {20dacfd5-d11f-43d0-b6f5-77fd38602331} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.5:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.5:8123'. Failed at try 10/10. 2025.03.05 21:16:06.916228 [ 11276 ] {20dacfd5-d11f-43d0-b6f5-77fd38602331} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.2:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.2:8123'. Failed at try 10/10. 2025.03.05 21:16:06.916308 [ 23621 ] {49aee471-cdef-41ba-9f2a-c234468dabc4} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39784) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.916501 [ 23621 ] {49aee471-cdef-41ba-9f2a-c234468dabc4} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.918315 [ 11339 ] {20dacfd5-d11f-43d0-b6f5-77fd38602331} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.3:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.3:8123'. Failed at try 10/10. 2025.03.05 21:16:06.918398 [ 34718 ] {20dacfd5-d11f-43d0-b6f5-77fd38602331} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.1:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.1:8123'. Failed at try 10/10. 2025.03.05 21:16:06.918477 [ 11411 ] {20dacfd5-d11f-43d0-b6f5-77fd38602331} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.4:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.4:8123'. Failed at try 10/10. 2025.03.05 21:16:06.918682 [ 5917 ] {20dacfd5-d11f-43d0-b6f5-77fd38602331} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.7:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.7:8123'. Failed at try 10/10. 2025.03.05 21:16:06.918973 [ 34781 ] {20dacfd5-d11f-43d0-b6f5-77fd38602331} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.10:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.10:8123'. Failed at try 10/10. 2025.03.05 21:16:06.919041 [ 11334 ] {20dacfd5-d11f-43d0-b6f5-77fd38602331} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.9:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.9:8123'. Failed at try 10/10. 2025.03.05 21:16:06.919328 [ 1629 ] {20dacfd5-d11f-43d0-b6f5-77fd38602331} ReadWriteBufferFromHTTP: Failed to make request to 'http://128.0.0.6:8123/?query=SELECT+sleep(1)'. Error: 'Timeout: connect timed out: 128.0.0.6:8123'. Failed at try 10/10. 2025.03.05 21:16:06.920083 [ 12524 ] {20dacfd5-d11f-43d0-b6f5-77fd38602331} executeQuery: Poco::Exception. Code: 1000, e.code() = 0, Timeout: connect timed out: 128.0.0.1:8123 (version 24.3.12.76.altinitystable) (from [::1]:43258) (comment: 02044_url_glob_parallel_connection_refused.sh) (in query: SELECT * FROM url('http://128.0.0.{1..10}:8123/?query=SELECT+sleep(1)', TSV, 'x UInt8')), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:37: Poco::Exception::Exception(String const&, String const&, int) @ 0x000000003697aad2 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:148: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x0000000036981c9b 3. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000367ad1eb 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:214: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x000000003677648a 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:0: Poco::Net::HTTPClientSession::reconnect() @ 0x0000000036752c54 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c7216 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:540: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c51d9 8. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration) @ 0x0000000024ab5256 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:246: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000290691b5 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x0000000024735e3d 17. DB::ReadBuffer::next() @ 0x0000000018778250 18. ./src/IO/ReadHelpers.h:1832: DB::skipBOMIfExists(DB::ReadBuffer&) @ 0x00000000336c0912 19. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:79: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x00000000336b545d 20. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:103: DB::IRowInputFormat::read() @ 0x0000000033662a38 21. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 22. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 26. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 28. ./build_docker/./src/Storages/StorageURL.cpp:406: DB::StorageURLSource::generate() @ 0x00000000326594a1 29. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 2025.03.05 21:16:06.921314 [ 12524 ] {20dacfd5-d11f-43d0-b6f5-77fd38602331} TCPHandler: Code: 1000. DB::Exception: Timeout: connect timed out: 128.0.0.1:8123. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:37: Poco::Exception::Exception(String const&, String const&, int) @ 0x000000003697aad2 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:148: Poco::TimeoutException::TimeoutException(String const&, String const&, int) @ 0x0000000036981c9b 3. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:0: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000367ad1eb 4. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:214: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x000000003677648a 5. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:0: Poco::Net::HTTPClientSession::reconnect() @ 0x0000000036752c54 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c7216 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:540: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&) @ 0x00000000249c51d9 8. ./build_docker/./src/IO/HTTPCommon.cpp:0: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration) @ 0x0000000024ab5256 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:246: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000290691b5 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 15. DB::ReadBuffer::next() @ 0x0000000018778250 16. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x0000000024735e3d 17. DB::ReadBuffer::next() @ 0x0000000018778250 18. ./src/IO/ReadHelpers.h:1832: DB::skipBOMIfExists(DB::ReadBuffer&) @ 0x00000000336c0912 19. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:79: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x00000000336b545d 20. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:103: DB::IRowInputFormat::read() @ 0x0000000033662a38 21. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003357d3f5 22. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 26. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000033573d94 28. ./build_docker/./src/Storages/StorageURL.cpp:406: DB::StorageURLSource::generate() @ 0x00000000326594a1 29. ./src/Processors/Chunk.h:90: DB::ISource::tryGenerate() @ 0x000000003353fbd4 30. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 2025.03.05 21:16:06.921530 [ 12524 ] {20dacfd5-d11f-43d0-b6f5-77fd38602331} TCPHandler: Client has gone away. 2025.03.05 21:16:06.950599 [ 23553 ] {7609b764-5ed9-4585-809c-fd4bac54a99a} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_tmog7hsv.dict1, because some tables depend on it: test_tmog7hsv.t (81f806c8-c744-48a8-b804-ef2707dff93e), test_tmog7hsv.join. (HAVE_DEPENDENT_OBJECTS) (version 24.3.12.76.altinitystable) (from [::1]:39790) (comment: 01160_table_dependencies.sh) (in query: rename database test_tmog7hsv to test_tmog7hsv_1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000002fda7392 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1456: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9b344 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9ba54 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseAtomic::renameDatabase(std::shared_ptr, String const&) @ 0x000000002f746946 7. ./src/QueryPipeline/BlockIO.h:14: DB::InterpreterRenameQuery::executeToDatabase(DB::ASTRenameQuery const&, std::vector> const&) @ 0x0000000030f465ab 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:75: DB::InterpreterRenameQuery::execute() @ 0x0000000030f452ec 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:06.951238 [ 23553 ] {7609b764-5ed9-4585-809c-fd4bac54a99a} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_tmog7hsv.dict1, because some tables depend on it: test_tmog7hsv.t (81f806c8-c744-48a8-b804-ef2707dff93e), test_tmog7hsv.join. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v8::join_view, std::__wrap_iter, char>&&) @ 0x000000002fda7392 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1456: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9b344 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002fd9ba54 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseAtomic::renameDatabase(std::shared_ptr, String const&) @ 0x000000002f746946 7. ./src/QueryPipeline/BlockIO.h:14: DB::InterpreterRenameQuery::executeToDatabase(DB::ASTRenameQuery const&, std::vector> const&) @ 0x0000000030f465ab 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:75: DB::InterpreterRenameQuery::execute() @ 0x0000000030f452ec 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.236455 [ 834 ] {} test_ztc1o1yj.concurrent_optimize_table (87f9a0f3-f38b-4472-a7c0-8bc67c44f087): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3522: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000032459618 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f0fe371 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002f103012 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002f103e52 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:07.237768 [ 81460 ] {3cf5b759-6a20-4787-9191-cea3785c8c0e} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39888) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.238035 [ 81460 ] {3cf5b759-6a20-4787-9191-cea3785c8c0e} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.239551 [ 23498 ] {24fe7a7c-9dcb-4361-baba-b3c28fba5e61} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:39870) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.240126 [ 23621 ] {ea56ae30-85bd-4179-b13e-ef530baf4c2b} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:39836) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.242338 [ 23621 ] {ea56ae30-85bd-4179-b13e-ef530baf4c2b} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.243099 [ 23498 ] {24fe7a7c-9dcb-4361-baba-b3c28fba5e61} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.257111 [ 48611 ] {2824e5b3-0bfc-4059-a15c-19017a831564} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:39856) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.257595 [ 23553 ] {23b39797-7438-41ca-bf30-b2e3e2f1eebd} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:39848) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.258837 [ 48611 ] {2824e5b3-0bfc-4059-a15c-19017a831564} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.259277 [ 23553 ] {23b39797-7438-41ca-bf30-b2e3e2f1eebd} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.265663 [ 23635 ] {6be93d95-2eb3-4351-840a-8a42f082071f} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39914) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.265896 [ 23635 ] {6be93d95-2eb3-4351-840a-8a42f082071f} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.329118 [ 48611 ] {2ca361a6-f83b-4eb3-91fa-740a4458817d} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:39944) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.329537 [ 48611 ] {2ca361a6-f83b-4eb3-91fa-740a4458817d} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.329676 [ 81460 ] {3ebedab5-d8c8-4259-9d66-5adc472ae4d1} executeQuery: Code: 81. DB::Exception: Database test_tmog7hsv_2 does not exist. Maybe you meant test_tmog7hsv?. (UNKNOWN_DATABASE) (version 24.3.12.76.altinitystable) (from [::1]:39956) (comment: 01160_table_dependencies.sh) (in query: rename table t to test_tmog7hsv_2.t), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a7c0 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:146: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f472c1 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.331030 [ 81460 ] {3ebedab5-d8c8-4259-9d66-5adc472ae4d1} TCPHandler: Code: 81. DB::Exception: Database test_tmog7hsv_2 does not exist. Maybe you meant test_tmog7hsv?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a7c0 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:146: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000030f472c1 6. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000030f45314 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.533731 [ 23611 ] {fc572449-c2ae-4087-86b6-3858b2bca6a4} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40022) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.534128 [ 23611 ] {fc572449-c2ae-4087-86b6-3858b2bca6a4} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.539733 [ 23621 ] {e3419ac0-620a-4f0f-9ffd-1e84f429748e} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:39998) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.542184 [ 23621 ] {e3419ac0-620a-4f0f-9ffd-1e84f429748e} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.556702 [ 23498 ] {237bf160-bdc3-432d-be1a-a04401184016} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40036) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.556999 [ 23498 ] {237bf160-bdc3-432d-be1a-a04401184016} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.579206 [ 81460 ] {0de0807c-325b-4246-b492-7305c6563073} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40056) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.579484 [ 81460 ] {0de0807c-325b-4246-b492-7305c6563073} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.579802 [ 81468 ] {b31d0884-f545-4632-b570-2e03d95b7a94} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40060) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:07.580021 [ 81468 ] {b31d0884-f545-4632-b570-2e03d95b7a94} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:08.067539 [ 81460 ] {b000f123-0fec-4379-8044-feb642667973} executeQuery: Code: 659. DB::Exception: Connection lost on attempt to commit transaction (336, 35, 17a9e4e3-6079-46b5-96d2-65b6c5db6991), will finalize it later: Fault injected (after commit). (UNKNOWN_STATUS_OF_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::1]:40270) (comment: 01133_begin_commit_race.sh) (in query: COMMIT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::TransactionID const&, String const&) @ 0x00000000315a34bb 4. ./build_docker/./src/Interpreters/TransactionLog.cpp:431: DB::TransactionLog::commitTransaction(std::shared_ptr const&, bool) @ 0x00000000315a1a64 5. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:0: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x00000000317181a6 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:08.067812 [ 81460 ] {b000f123-0fec-4379-8044-feb642667973} TCPHandler: Code: 659. DB::Exception: Connection lost on attempt to commit transaction (336, 35, 17a9e4e3-6079-46b5-96d2-65b6c5db6991), will finalize it later: Fault injected (after commit). (UNKNOWN_STATUS_OF_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::TransactionID const&, String const&) @ 0x00000000315a34bb 4. ./build_docker/./src/Interpreters/TransactionLog.cpp:431: DB::TransactionLog::commitTransaction(std::shared_ptr const&, bool) @ 0x00000000315a1a64 5. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:0: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x00000000317181a6 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:08.258244 [ 48603 ] {01167_isolation_hermitage_test_8lyq5r6c_tx17_27238} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_33.txt' with part 'all_30_30_0' reason: 'Serialization error: part all_30_30_0 is locked by transaction 9712883091501614210'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:54092) (in query: alter table test update value = 11 where id = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x000000003308621e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d657 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:08.258462 [ 48603 ] {01167_isolation_hermitage_test_8lyq5r6c_tx17_27238} DynamicQueryHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_33.txt' with part 'all_30_30_0' reason: 'Serialization error: part all_30_30_0 is locked by transaction 9712883091501614210'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000032d7db89 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000032d7d9c0 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:622: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003308b22b 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x000000003308621e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003308d657 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000307957ca 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 13. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:08.318706 [ 48603 ] {01167_isolation_hermitage_test_8lyq5r6c_tx17_17589} executeQuery: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:54108) (in query: commit), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:08.318910 [ 48603 ] {01167_isolation_hermitage_test_8lyq5r6c_tx17_17589} DynamicQueryHandler: Code: 649. DB::Exception: Transaction is not in RUNNING state. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:62: DB::InterpreterTransactionControlQuery::executeCommit(std::shared_ptr) @ 0x000000003171853d 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterTransactionControlQuery::execute() @ 0x00000000317177a5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:08.675405 [ 891 ] {} test_ztc1o1yj.concurrent_optimize_table (81a6f481-a622-416c-ae14-c7d287c78402): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3522: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000032459618 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f0fe371 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002f103012 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002f103e52 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:08.709261 [ 863 ] {} test_ztc1o1yj.concurrent_optimize_table (81a6f481-a622-416c-ae14-c7d287c78402): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:254: DB::StorageReplicatedMergeTree::getZooKeeperAndAssertNotReadonly() const @ 0x00000000323932bc 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3757: DB::StorageReplicatedMergeTree::mergeSelectingTask()::$_0::operator()() const @ 0x000000003245e6de 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3877: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x000000003245d19a 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f0fe371 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002f103012 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002f103e52 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:08.711362 [ 23622 ] {ef0239d6-cb1f-4ba3-9ea0-e958566b9d23} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:40532) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:08.741974 [ 23597 ] {2a3417ca-7951-42a1-8ed0-881a8d8d9291} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:40522) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:08.742159 [ 14974 ] {0b5bc202-f29d-441a-99a0-4a34d239468b} executeQuery: Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED) (version 24.3.12.76.altinitystable) (from [::1]:40510) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:619: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000032fa4351 5. ./contrib/llvm-project/libcxx/include/tuple:1228: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000032fcf460 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1883: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000032fc20b3 7. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x000000003249d218 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249b6d2 9. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:08.742544 [ 23622 ] {ef0239d6-cb1f-4ba3-9ea0-e958566b9d23} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:08.742588 [ 48624 ] {ef7f00b5-b376-4a7f-a00a-e809f3bb9fb6} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:40542) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:08.742686 [ 14973 ] {57b86fbb-95e9-4360-927a-4d50441bd9c7} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40558) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:08.744189 [ 14974 ] {0b5bc202-f29d-441a-99a0-4a34d239468b} TCPHandler: Code: 236. DB::Exception: Log pulling is cancelled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:619: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000032fa4351 5. ./contrib/llvm-project/libcxx/include/tuple:1228: DB::ReplicatedMergeTreeMergePredicate::ReplicatedMergeTreeMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000032fcf460 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1883: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x0000000032fc20b3 7. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x000000003249d218 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249b6d2 9. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:08.744461 [ 23597 ] {2a3417ca-7951-42a1-8ed0-881a8d8d9291} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:08.745105 [ 48624 ] {ef7f00b5-b376-4a7f-a00a-e809f3bb9fb6} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:08.746083 [ 48581 ] {f3482cb7-7c84-4344-9585-d9240f9918a7} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:40570) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:08.747837 [ 48581 ] {f3482cb7-7c84-4344-9585-d9240f9918a7} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:08.752822 [ 14973 ] {57b86fbb-95e9-4360-927a-4d50441bd9c7} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.006166 [ 48624 ] {02f1072f-451c-46c0-8b4f-120933e6ac1e} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:38786) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.006492 [ 48624 ] {02f1072f-451c-46c0-8b4f-120933e6ac1e} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.012319 [ 23597 ] {8da3c05e-5a0a-47b4-8ba3-8c636fbbb448} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:38792) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.012568 [ 23597 ] {8da3c05e-5a0a-47b4-8ba3-8c636fbbb448} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.315533 [ 23597 ] {2930996a-6a34-4e30-b574-1d08729e3974} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:38932) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.316090 [ 23597 ] {2930996a-6a34-4e30-b574-1d08729e3974} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.320911 [ 23620 ] {c2b08cd1-5bc1-4416-baf9-c7c103b0c638} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:38952) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.321192 [ 23620 ] {c2b08cd1-5bc1-4416-baf9-c7c103b0c638} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.562842 [ 851 ] {} test_ztc1o1yj.concurrent_optimize_table (6d3e6a70-93a8-496d-9691-42cb94a61b55): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3522: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000032459618 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f0fe371 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002f103012 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002f103e52 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:09.596504 [ 14973 ] {3b999b05-7b7d-447e-bb3f-b3dde08b8eb0} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:39114) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.598850 [ 14973 ] {3b999b05-7b7d-447e-bb3f-b3dde08b8eb0} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.620936 [ 753 ] {} test_ztc1o1yj.concurrent_optimize_table (6d3e6a70-93a8-496d-9691-42cb94a61b55): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:254: DB::StorageReplicatedMergeTree::getZooKeeperAndAssertNotReadonly() const @ 0x00000000323932bc 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3757: DB::StorageReplicatedMergeTree::mergeSelectingTask()::$_0::operator()() const @ 0x000000003245e6de 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3877: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x000000003245d19a 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f0fe371 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002f103012 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002f103e52 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:09.746414 [ 14973 ] {a53c9c76-2e92-4080-9d63-40385f6f1810} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39150) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.746671 [ 14973 ] {a53c9c76-2e92-4080-9d63-40385f6f1810} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.767192 [ 23642 ] {d13fe200-7fe3-4dea-88d9-6aad1d2ca207} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39168) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.767447 [ 23642 ] {d13fe200-7fe3-4dea-88d9-6aad1d2ca207} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.796247 [ 14973 ] {449ec972-474c-4d30-aafd-3cbd4cb7db97} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39206) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.796566 [ 14973 ] {449ec972-474c-4d30-aafd-3cbd4cb7db97} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.807280 [ 730 ] {1b1df928-0926-4098-ade6-ac800c589259} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39232) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.807546 [ 730 ] {1b1df928-0926-4098-ade6-ac800c589259} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.822574 [ 48614 ] {f125a2e6-5184-4b74-8f69-3102296d7121} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39236) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.822874 [ 48614 ] {f125a2e6-5184-4b74-8f69-3102296d7121} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.989385 [ 14973 ] {74a6ab2f-c200-42a7-a83b-81af7e50dbe8} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39270) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:09.989852 [ 14973 ] {74a6ab2f-c200-42a7-a83b-81af7e50dbe8} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.039145 [ 48598 ] {ce3c7038-34bd-4183-828b-ccf4ae8111bb} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39320) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.039437 [ 48598 ] {ce3c7038-34bd-4183-828b-ccf4ae8111bb} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.044395 [ 23606 ] {28037a14-538f-4725-bb32-fb03a16d4ad7} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39342) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.044658 [ 23606 ] {28037a14-538f-4725-bb32-fb03a16d4ad7} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.057362 [ 730 ] {23aa8a15-3fb6-462f-8448-78697e499f54} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39354) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.057668 [ 730 ] {23aa8a15-3fb6-462f-8448-78697e499f54} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.124341 [ 730 ] {4683f0c4-6d68-4378-a998-b1714e396ccf} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39376) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.124662 [ 730 ] {4683f0c4-6d68-4378-a998-b1714e396ccf} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.148078 [ 81478 ] {7a4ae961-cfb2-484c-8831-c70742d7da89} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39388) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.148388 [ 81478 ] {7a4ae961-cfb2-484c-8831-c70742d7da89} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.234439 [ 81478 ] {cfa5865b-a3a2-4e7b-aafe-57c615702fba} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:39410) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.234791 [ 81478 ] {cfa5865b-a3a2-4e7b-aafe-57c615702fba} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.267758 [ 48614 ] {41238b73-4437-440e-87b5-946d919f3520} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39440) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.268178 [ 48614 ] {41238b73-4437-440e-87b5-946d919f3520} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.274323 [ 730 ] {22276b7f-846e-4f07-ae98-8a7942aa22c0} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39456) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.274571 [ 730 ] {22276b7f-846e-4f07-ae98-8a7942aa22c0} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.286286 [ 81478 ] {1eca733d-b8eb-49c0-921d-8a75a1cffb0d} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:39446) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.286614 [ 81478 ] {1eca733d-b8eb-49c0-921d-8a75a1cffb0d} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.304732 [ 48614 ] {b3eb71d2-b195-487e-8cf8-13e71395f0bd} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39484) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.305056 [ 48614 ] {b3eb71d2-b195-487e-8cf8-13e71395f0bd} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.347438 [ 48614 ] {2242a360-5140-4036-b18a-be1a8e75f3a9} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39522) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.347750 [ 48614 ] {2242a360-5140-4036-b18a-be1a8e75f3a9} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.375127 [ 730 ] {bc3c56bd-fd07-4969-81d9-362a11c01a59} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39528) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.375410 [ 730 ] {bc3c56bd-fd07-4969-81d9-362a11c01a59} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.514447 [ 730 ] {18fa5cfd-c5da-4599-ba92-ea9e1610c054} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39570) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.514733 [ 730 ] {18fa5cfd-c5da-4599-ba92-ea9e1610c054} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.546584 [ 23586 ] {53add3b6-5443-4997-bfbe-6b9c9b649a9a} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39608) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.546601 [ 48598 ] {87f6dbfa-fe03-4f63-b691-53586778e74f} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39604) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.546845 [ 23586 ] {53add3b6-5443-4997-bfbe-6b9c9b649a9a} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.546860 [ 48598 ] {87f6dbfa-fe03-4f63-b691-53586778e74f} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.598418 [ 81478 ] {9faa8383-13dd-45ee-97b0-46254ccdb8da} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39626) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.598740 [ 81478 ] {9faa8383-13dd-45ee-97b0-46254ccdb8da} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.632328 [ 48598 ] {b2401113-4a3c-4a73-8d2e-4d6294128208} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39652) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.665262 [ 48624 ] {c6594c3b-8cd6-4dc3-9ee1-9c271559f824} executeQuery: Code: 341. DB::Exception: Log entry log-0000000061 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED) (version 24.3.12.76.altinitystable) (from [::1]:39010) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6751: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x00000000324a1232 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249b92b 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.665306 [ 48598 ] {b2401113-4a3c-4a73-8d2e-4d6294128208} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.665324 [ 81478 ] {0ece33b4-5f54-4c1b-a246-5f950821bffb} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39674) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.665631 [ 81478 ] {0ece33b4-5f54-4c1b-a246-5f950821bffb} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:10.681944 [ 48624 ] {c6594c3b-8cd6-4dc3-9ee1-9c271559f824} TCPHandler: Code: 341. DB::Exception: Log entry log-0000000061 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6751: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x00000000324a1232 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249b92b 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:11.011949 [ 48598 ] {4ce19c11-7e15-48a7-810c-fb0d967fac75} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:39764) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:11.013833 [ 48598 ] {4ce19c11-7e15-48a7-810c-fb0d967fac75} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:11.050977 [ 48602 ] {f33022ff-40e1-44a5-8abe-352ef2140712} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39816) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:11.051255 [ 48602 ] {f33022ff-40e1-44a5-8abe-352ef2140712} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:11.052227 [ 23586 ] {7d359b27-17d9-4819-8e8f-9d631d5c70e5} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:39802) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:11.052449 [ 23586 ] {7d359b27-17d9-4819-8e8f-9d631d5c70e5} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:11.558935 [ 3522 ] {288a60ff-4c38-49e0-81e3-0ebc402871dd} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40002) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:11.559230 [ 3522 ] {288a60ff-4c38-49e0-81e3-0ebc402871dd} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:11.565560 [ 23562 ] {c010a19a-1b08-4099-9f54-f705c3e59833} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40008) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:11.565855 [ 23562 ] {c010a19a-1b08-4099-9f54-f705c3e59833} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:11.590539 [ 48602 ] {a25a7a16-edfd-4cd8-9ef3-4b3a929b7e62} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40016) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:11.590824 [ 48602 ] {a25a7a16-edfd-4cd8-9ef3-4b3a929b7e62} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:11.635852 [ 23562 ] {3ad7f1b1-263a-4038-b3a1-f6d6140a2830} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:40042) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5741: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249a896 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:11.646358 [ 23562 ] {3ad7f1b1-263a-4038-b3a1-f6d6140a2830} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5741: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249a896 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.118710 [ 22858 ] {9b3853f8-c35c-4285-8c97-e5049e79a7f4} executeQuery: Code: 48. DB::Exception: Table engine Join supports only DELETE mutations. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:40238) (comment: 01162_strange_mutations.sh) (in query: ALTER TABLE test UPDATE test = (SELECT groupArray(id) FROM t1)[n - 99] WHERE 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageJoin.cpp:122: DB::StorageJoin::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x0000000032246907 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795541 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.119071 [ 22858 ] {9b3853f8-c35c-4285-8c97-e5049e79a7f4} TCPHandler: Code: 48. DB::Exception: Table engine Join supports only DELETE mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageJoin.cpp:122: DB::StorageJoin::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x0000000032246907 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000030795541 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:71: DB::InterpreterAlterQuery::execute() @ 0x0000000030791f0d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.225786 [ 1166 ] {} test_ztc1o1yj.concurrent_optimize_table (9f4bcc40-84ca-407b-a045-2bda79aea23a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3522: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000032459618 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f0fe371 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002f103012 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002f103e52 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:12.242020 [ 5338 ] {fc778ef7-4f6e-419d-b93d-6a01d49b4d35} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:40240) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.244164 [ 5338 ] {fc778ef7-4f6e-419d-b93d-6a01d49b4d35} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.244224 [ 22858 ] {2809e36b-82eb-49c3-be5c-da463f8d1454} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:40274) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.245976 [ 22858 ] {2809e36b-82eb-49c3-be5c-da463f8d1454} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.301473 [ 956 ] {} test_ztc1o1yj.concurrent_optimize_table (9f4bcc40-84ca-407b-a045-2bda79aea23a): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:254: DB::StorageReplicatedMergeTree::getZooKeeperAndAssertNotReadonly() const @ 0x00000000323932bc 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3757: DB::StorageReplicatedMergeTree::mergeSelectingTask()::$_0::operator()() const @ 0x000000003245e6de 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3877: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x000000003245d19a 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f0fe371 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002f103012 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002f103e52 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:12.424110 [ 23573 ] {adc73681-6ddb-4ffa-beb0-80a392535753} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40354) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.424490 [ 23573 ] {adc73681-6ddb-4ffa-beb0-80a392535753} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.450051 [ 23628 ] {ca9f3e3b-79f2-4083-b480-f3aaca491006} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40372) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.450757 [ 23628 ] {ca9f3e3b-79f2-4083-b480-f3aaca491006} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.453844 [ 22858 ] {d0ee9e99-e842-4c2d-a915-b0c2618ba87e} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40388) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.454143 [ 22858 ] {d0ee9e99-e842-4c2d-a915-b0c2618ba87e} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.481312 [ 23635 ] {461ef181-d14e-435b-8ddb-c837879ba57a} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40396) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.481596 [ 23635 ] {461ef181-d14e-435b-8ddb-c837879ba57a} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.503931 [ 81473 ] {cc2f18bd-625c-4364-beb3-cba0e417e714} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40408) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.504183 [ 81473 ] {cc2f18bd-625c-4364-beb3-cba0e417e714} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.550173 [ 23553 ] {de4656eb-be29-467e-9198-431228260486} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40424) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.550427 [ 23553 ] {de4656eb-be29-467e-9198-431228260486} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.700280 [ 23553 ] {e36784e8-494c-4006-a79c-18399bcff0d5} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40442) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.700521 [ 23553 ] {e36784e8-494c-4006-a79c-18399bcff0d5} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.703523 [ 23635 ] {a08017bb-5413-40bd-95b4-349458f5f31a} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40452) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.703771 [ 23635 ] {a08017bb-5413-40bd-95b4-349458f5f31a} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.727082 [ 81471 ] {66a6c413-6091-44f5-a028-1891b9d1873e} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40492) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.727352 [ 81471 ] {66a6c413-6091-44f5-a028-1891b9d1873e} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.737874 [ 23597 ] {a0243782-c232-481a-84f6-f4a2cc0c0141} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40506) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.738313 [ 23597 ] {a0243782-c232-481a-84f6-f4a2cc0c0141} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.743128 [ 14973 ] {705a7539-e486-47ac-a8d7-d5d2af59ac86} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:40502) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.743522 [ 14973 ] {705a7539-e486-47ac-a8d7-d5d2af59ac86} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.809364 [ 23553 ] {6e85eb7a-8068-4b15-bc2b-b62f6841ee8a} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40530) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.809867 [ 23553 ] {6e85eb7a-8068-4b15-bc2b-b62f6841ee8a} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.817506 [ 81473 ] {5fb6a85e-b141-42db-8cf1-fcc7d82d6bf8} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40542) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.817776 [ 81473 ] {5fb6a85e-b141-42db-8cf1-fcc7d82d6bf8} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.964364 [ 81473 ] {a5f997a8-f806-4b02-a87b-99c0cb69747b} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40580) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.964854 [ 81473 ] {a5f997a8-f806-4b02-a87b-99c0cb69747b} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.972394 [ 14973 ] {06a21049-807f-43e4-bb3f-70712088b9b4} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40614) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.972741 [ 14973 ] {06a21049-807f-43e4-bb3f-70712088b9b4} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.976880 [ 23553 ] {c0d6f0f2-429d-4d7b-8c2b-05cb9670f75b} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40628) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.977173 [ 23553 ] {c0d6f0f2-429d-4d7b-8c2b-05cb9670f75b} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.987119 [ 23597 ] {9108b60c-5f47-477a-8333-48bad052e93e} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40640) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:12.987488 [ 23597 ] {9108b60c-5f47-477a-8333-48bad052e93e} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.197413 [ 23635 ] {62130f4a-3f5f-4f72-b8e0-bcd6f180680c} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40666) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.197713 [ 23635 ] {62130f4a-3f5f-4f72-b8e0-bcd6f180680c} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.215083 [ 23597 ] {5e14e8ae-2ffb-4e24-9989-64f3aab4f588} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40694) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.215356 [ 23597 ] {5e14e8ae-2ffb-4e24-9989-64f3aab4f588} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.215765 [ 14973 ] {a242d6cb-1519-4a09-a65a-b4b3967494cb} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40702) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.216062 [ 14973 ] {a242d6cb-1519-4a09-a65a-b4b3967494cb} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.219977 [ 81471 ] {4955122b-6c4c-41da-9943-ada385481f8d} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40710) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.220243 [ 81471 ] {4955122b-6c4c-41da-9943-ada385481f8d} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.241695 [ 3522 ] {760f516b-ff2d-452d-af95-a2a110826081} executeQuery: Code: 341. DB::Exception: Log entry log-0000000130 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED) (version 24.3.12.76.altinitystable) (from [::1]:40180) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6751: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x00000000324a1232 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249b92b 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.242079 [ 3522 ] {760f516b-ff2d-452d-af95-a2a110826081} TCPHandler: Code: 341. DB::Exception: Log entry log-0000000130 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6751: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x00000000324a1232 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249b92b 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.280305 [ 23635 ] {a6667d38-a767-404e-83de-b6684dee049d} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40720) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.280541 [ 23635 ] {a6667d38-a767-404e-83de-b6684dee049d} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.287650 [ 81473 ] {52dc36cd-af6d-4710-949e-fad753031ca6} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:40732) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.287864 [ 81473 ] {52dc36cd-af6d-4710-949e-fad753031ca6} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.299880 [ 23610 ] {b7ce4346-594d-45ac-9973-0a2b555b8718} executeQuery: Code: 341. DB::Exception: Log entry log-0000000142 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED) (version 24.3.12.76.altinitystable) (from [::1]:40250) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6751: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x00000000324a1232 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249b92b 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.300168 [ 23610 ] {b7ce4346-594d-45ac-9973-0a2b555b8718} TCPHandler: Code: 341. DB::Exception: Log entry log-0000000142 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6751: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x00000000324a1232 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249b92b 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.521177 [ 23620 ] {fba3c3df-8f10-4b23-bac2-1244800b423b} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:40816) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.521383 [ 23642 ] {a6a57232-dd77-4afd-9f69-74e6c36280d0} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:40826) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.521816 [ 81473 ] {84fe5823-7f01-49af-b3b0-257c49e45840} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:40764) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.523772 [ 23620 ] {fba3c3df-8f10-4b23-bac2-1244800b423b} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.526356 [ 14973 ] {26a40649-83ec-4df0-b255-e0429b4c7f7a} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:40794) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.528458 [ 14973 ] {26a40649-83ec-4df0-b255-e0429b4c7f7a} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.529204 [ 81473 ] {84fe5823-7f01-49af-b3b0-257c49e45840} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:13.529385 [ 23642 ] {a6a57232-dd77-4afd-9f69-74e6c36280d0} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.128405 [ 23635 ] {3bdfbe7b-7fb5-42c1-9d3e-9d7d8d54010b} executeQuery: Code: 403. DB::Exception: JOIN _table_function.remote AS __table1 ALL INNER JOIN system.one AS __table2 ON __table2.dummy = 1 cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:40996) (comment: 01081_PartialSortingTransform_full_column.sql) (in query: select 1 from remote('127.{1,2}', currentDatabase(), test_01081) lhs join system.one as rhs on rhs.dummy = 1 order by 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000003100323f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc67c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.128600 [ 23635 ] {3bdfbe7b-7fb5-42c1-9d3e-9d7d8d54010b} TCPHandler: Code: 403. DB::Exception: JOIN _table_function.remote AS __table1 ALL INNER JOIN system.one AS __table2 ON __table2.dummy = 1 cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000003100323f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc67c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.143261 [ 23635 ] {a4d74975-0172-4c6b-afc8-d6c968f6eaca} executeQuery: Code: 403. DB::Exception: JOIN _table_function.remote AS __table1 ALL INNER JOIN system.one AS __table2 ON __table2.dummy = 1 cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:40996) (comment: 01081_PartialSortingTransform_full_column.sql) (in query: select 1 from remote('127.{1,2}', currentDatabase(), test_01081) lhs join system.one as rhs on rhs.dummy = 1 order by 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000003100323f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc67c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.143461 [ 23635 ] {a4d74975-0172-4c6b-afc8-d6c968f6eaca} TCPHandler: Code: 403. DB::Exception: JOIN _table_function.remote AS __table1 ALL INNER JOIN system.one AS __table2 ON __table2.dummy = 1 cannot get JOIN keys. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000310972e4 5. ./build_docker/./src/Planner/PlannerJoins.cpp:655: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000031092d3f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000031069e92 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000003100323f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc67c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.193467 [ 930 ] {} test_ztc1o1yj.concurrent_optimize_table (f857fc7b-3085-49e1-861a-72b3b1acfa08): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3522: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000032459618 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f0fe371 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002f103012 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002f103e52 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:14.198749 [ 14973 ] {fd95164e-d993-49be-9a7e-48fa68e47b2b} executeQuery: Code: 218. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table is dropped or detached. (TABLE_IS_DROPPED) (version 24.3.12.76.altinitystable) (from [::1]:41078) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Storages/IStorage.cpp:64: DB::IStorage::lockForShare(String const&, std::chrono::duration> const&) @ 0x00000000320dd146 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033c9ef7a 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.199007 [ 14973 ] {fd95164e-d993-49be-9a7e-48fa68e47b2b} TCPHandler: Code: 218. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table is dropped or detached. (TABLE_IS_DROPPED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Storages/IStorage.cpp:64: DB::IStorage::lockForShare(String const&, std::chrono::duration> const&) @ 0x00000000320dd146 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033c9ef7a 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.199749 [ 23620 ] {b4df2053-422c-4f0b-8e66-b711cc5cab6d} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:41054) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.200157 [ 23597 ] {c895e51f-e2bc-40b5-9ba6-103421ff7563} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:41044) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.201439 [ 23620 ] {b4df2053-422c-4f0b-8e66-b711cc5cab6d} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.202517 [ 23597 ] {c895e51f-e2bc-40b5-9ba6-103421ff7563} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.212909 [ 81471 ] {9461e919-d5d2-404b-9682-06d9b5373553} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:41012) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.214808 [ 81471 ] {9461e919-d5d2-404b-9682-06d9b5373553} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.227518 [ 81473 ] {82c03c90-5a83-4c9c-aa15-974cf942732e} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41108) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.227788 [ 81473 ] {82c03c90-5a83-4c9c-aa15-974cf942732e} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.330237 [ 14973 ] {3e0a1dc1-a32e-49f3-bf2d-f29461fc7d95} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41126) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.330534 [ 14973 ] {3e0a1dc1-a32e-49f3-bf2d-f29461fc7d95} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.379161 [ 14973 ] {701ca5bd-0570-4a20-9ff6-8ac1e2e89b4c} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:41148) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5741: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249a896 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.379420 [ 14973 ] {701ca5bd-0570-4a20-9ff6-8ac1e2e89b4c} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5741: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249a896 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.698488 [ 1039 ] {} test_ztc1o1yj.concurrent_optimize_table (4d379867-f1e9-4286-88a2-ef3ec38fc9c6): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3522: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000032459618 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f0fe371 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002f103012 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002f103e52 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:14.727714 [ 949 ] {} test_ztc1o1yj.concurrent_optimize_table (4d379867-f1e9-4286-88a2-ef3ec38fc9c6): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:254: DB::StorageReplicatedMergeTree::getZooKeeperAndAssertNotReadonly() const @ 0x00000000323932bc 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3757: DB::StorageReplicatedMergeTree::mergeSelectingTask()::$_0::operator()() const @ 0x000000003245e6de 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3877: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x000000003245d19a 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f0fe371 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002f103012 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002f103e52 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:14.764419 [ 48603 ] {6b28a863-b06f-4eb7-a7ae-66a60b3013c6} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41300) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.764689 [ 48603 ] {6b28a863-b06f-4eb7-a7ae-66a60b3013c6} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.819825 [ 23642 ] {8a39ba45-a616-4e81-9235-d8129e7ea66a} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41320) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.820112 [ 23642 ] {8a39ba45-a616-4e81-9235-d8129e7ea66a} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.822982 [ 48581 ] {b9c5746f-446e-45d0-8f25-b70458d882c8} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41334) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.823238 [ 48581 ] {b9c5746f-446e-45d0-8f25-b70458d882c8} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.824039 [ 48603 ] {be592f77-0708-4059-b369-5ea923b70aac} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41324) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.824396 [ 48603 ] {be592f77-0708-4059-b369-5ea923b70aac} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.826182 [ 48624 ] {bcfb3761-a9e0-4110-a94c-a492c7123676} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41336) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.826451 [ 48624 ] {bcfb3761-a9e0-4110-a94c-a492c7123676} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.829707 [ 730 ] {8cfd86d1-f620-42c2-b738-c80ffcba009b} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41348) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.829975 [ 730 ] {8cfd86d1-f620-42c2-b738-c80ffcba009b} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.839351 [ 81478 ] {ca10eeed-804b-446e-ae27-971db0daedd7} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41354) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.839614 [ 81478 ] {ca10eeed-804b-446e-ae27-971db0daedd7} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.843303 [ 48614 ] {d27e7e8c-ee65-4123-979e-d4be9735294e} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41368) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:14.843580 [ 48614 ] {d27e7e8c-ee65-4123-979e-d4be9735294e} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.043887 [ 23642 ] {f20b5157-46c8-4945-a22d-5c440ed055c6} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41446) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.044171 [ 23642 ] {f20b5157-46c8-4945-a22d-5c440ed055c6} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.061864 [ 23577 ] {8a3d577b-b2b9-4f20-9f1b-4168775afeae} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41462) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.062161 [ 23577 ] {8a3d577b-b2b9-4f20-9f1b-4168775afeae} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.063891 [ 48603 ] {cfc5109b-a4cf-47db-82c0-1493690d2eeb} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41470) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.064219 [ 48603 ] {cfc5109b-a4cf-47db-82c0-1493690d2eeb} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.081626 [ 23642 ] {9534a763-af7d-40ee-a4be-55cf97559b35} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41486) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.081882 [ 23642 ] {9534a763-af7d-40ee-a4be-55cf97559b35} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.203495 [ 48581 ] {f396e8fa-64d9-4eb3-a60c-255141546e98} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41502) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.203721 [ 48581 ] {f396e8fa-64d9-4eb3-a60c-255141546e98} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.277473 [ 48624 ] {bce74112-8611-402a-b060-ae9d0decf8e7} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41524) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.277726 [ 48624 ] {bce74112-8611-402a-b060-ae9d0decf8e7} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.307283 [ 730 ] {122a9a05-9f7f-4a8b-abf0-8262ec217f6c} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41546) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.307514 [ 730 ] {122a9a05-9f7f-4a8b-abf0-8262ec217f6c} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.315210 [ 48624 ] {f9ce22d5-12e4-4550-90b3-0b151c467793} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41562) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.315484 [ 48624 ] {f9ce22d5-12e4-4550-90b3-0b151c467793} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.320554 [ 81478 ] {dbaa48d4-32d0-4377-a2ba-e9d1e2d14124} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41570) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.320833 [ 81478 ] {dbaa48d4-32d0-4377-a2ba-e9d1e2d14124} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.322616 [ 48614 ] {089ca32c-41fe-4ead-8441-6a3a7b121748} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41584) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.322877 [ 48614 ] {089ca32c-41fe-4ead-8441-6a3a7b121748} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.335241 [ 48598 ] {4794055c-0f8c-418c-b5ae-012c7ac8ec6b} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41586) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.335585 [ 48598 ] {4794055c-0f8c-418c-b5ae-012c7ac8ec6b} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.417581 [ 730 ] {e2433022-5f34-45b3-842c-f936eddd02b1} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41614) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.417871 [ 730 ] {e2433022-5f34-45b3-842c-f936eddd02b1} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.442217 [ 48624 ] {9a6d67bc-7d12-4f20-8196-29dac7c381d9} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41630) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.442572 [ 48624 ] {9a6d67bc-7d12-4f20-8196-29dac7c381d9} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.511602 [ 48624 ] {008bf36f-898c-48b4-a5dc-a3c644030cf7} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41642) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.511908 [ 48624 ] {008bf36f-898c-48b4-a5dc-a3c644030cf7} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.563612 [ 23577 ] {b374c88d-adc9-49fa-a894-d25ba1036dbb} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41644) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.563884 [ 23577 ] {b374c88d-adc9-49fa-a894-d25ba1036dbb} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.577704 [ 48624 ] {24fef24b-2241-4b61-a2fe-ae5207b3e308} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41656) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.578023 [ 48624 ] {24fef24b-2241-4b61-a2fe-ae5207b3e308} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.580515 [ 730 ] {098cb378-edc2-49b1-adf8-ca19fad8a139} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41670) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.580826 [ 730 ] {098cb378-edc2-49b1-adf8-ca19fad8a139} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.661775 [ 23577 ] {0cb6ef22-1d7e-4f64-ab02-5823cb01bfab} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:41704) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.662046 [ 23577 ] {0cb6ef22-1d7e-4f64-ab02-5823cb01bfab} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.674666 [ 48624 ] {bbedd63a-ec36-41a5-8a3a-f450ae8741d6} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41726) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.674917 [ 48624 ] {bbedd63a-ec36-41a5-8a3a-f450ae8741d6} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.734183 [ 81473 ] {a3345f58-ed27-4cbd-8145-17a00a4f9f3d} executeQuery: Code: 341. DB::Exception: Log entry log-0000000083 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED) (version 24.3.12.76.altinitystable) (from [::1]:41268) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6751: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x00000000324a1232 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249b92b 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.734643 [ 81473 ] {a3345f58-ed27-4cbd-8145-17a00a4f9f3d} TCPHandler: Code: 341. DB::Exception: Log entry log-0000000083 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6751: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x00000000324a1232 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249b92b 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.758356 [ 23577 ] {f6fb154f-d85d-43e2-b6d4-53d79422dfd7} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:41740) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:15.758667 [ 23577 ] {f6fb154f-d85d-43e2-b6d4-53d79422dfd7} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.685422 [ 1098 ] {} test_ztc1o1yj.concurrent_optimize_table (eb5e2482-1325-47ca-879f-a455ed653da1): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3522: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000032459618 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f0fe371 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002f103012 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002f103e52 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:16.687636 [ 48602 ] {b1161ec1-efec-446c-8115-f8ec059fe442} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:42104) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.690098 [ 48602 ] {b1161ec1-efec-446c-8115-f8ec059fe442} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.691722 [ 23628 ] {694ff079-aae7-4edd-9084-97455ecdaee6} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:42122) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5741: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249a896 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.691988 [ 23628 ] {694ff079-aae7-4edd-9084-97455ecdaee6} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5741: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249a896 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.693567 [ 1099 ] {} test_ztc1o1yj.concurrent_optimize_table (eb5e2482-1325-47ca-879f-a455ed653da1): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:254: DB::StorageReplicatedMergeTree::getZooKeeperAndAssertNotReadonly() const @ 0x00000000323932bc 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3757: DB::StorageReplicatedMergeTree::mergeSelectingTask()::$_0::operator()() const @ 0x000000003245e6de 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3877: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x000000003245d19a 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f0fe371 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002f103012 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002f103e52 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:16.694286 [ 5338 ] {279f9f75-1db4-4ec3-99ce-d215babdbf4e} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:42094) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.696400 [ 5338 ] {279f9f75-1db4-4ec3-99ce-d215babdbf4e} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.702858 [ 23573 ] {9c6c8f08-c3a4-4e80-8520-d055e1dfc238} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:42114) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.711723 [ 23573 ] {9c6c8f08-c3a4-4e80-8520-d055e1dfc238} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.712800 [ 48599 ] {ac12728d-d0ce-493f-8a1c-fb9108850f30} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42130) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.713244 [ 48599 ] {ac12728d-d0ce-493f-8a1c-fb9108850f30} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.742141 [ 5338 ] {c61b5e90-5af0-49e3-aa9e-78a128d401a1} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42144) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.742415 [ 5338 ] {c61b5e90-5af0-49e3-aa9e-78a128d401a1} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.792800 [ 5338 ] {2415377b-b727-463c-abcb-621c5b58a85f} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42186) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.793048 [ 5338 ] {2415377b-b727-463c-abcb-621c5b58a85f} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.859470 [ 14920 ] {efd119a6-a164-4d37-bb2a-b4c35410e2fc} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42208) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.859808 [ 14920 ] {efd119a6-a164-4d37-bb2a-b4c35410e2fc} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.965073 [ 48602 ] {235de420-53de-4003-8f44-636dba8030e7} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42248) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.965405 [ 48602 ] {235de420-53de-4003-8f44-636dba8030e7} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.965638 [ 14920 ] {25e1d954-42a9-4894-800b-23e579da6fc7} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42264) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.966019 [ 14920 ] {25e1d954-42a9-4894-800b-23e579da6fc7} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.970651 [ 23573 ] {994ee527-1322-4473-959a-752fb5dc5adb} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42278) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.971093 [ 23573 ] {994ee527-1322-4473-959a-752fb5dc5adb} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.983816 [ 5338 ] {0dc0905a-ef55-4444-98a3-47d8afa65ae9} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42286) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:16.984138 [ 5338 ] {0dc0905a-ef55-4444-98a3-47d8afa65ae9} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.203852 [ 23628 ] {c9a57c58-ea77-4695-9028-d7b54afd3eba} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42346) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.204131 [ 23628 ] {c9a57c58-ea77-4695-9028-d7b54afd3eba} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.204334 [ 48599 ] {f603976f-42cd-49ff-bfd8-60ac738e35a4} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42352) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.204623 [ 48599 ] {f603976f-42cd-49ff-bfd8-60ac738e35a4} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.211152 [ 22866 ] {7382a2a3-30d7-4d86-a828-8514bd4e7efb} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42366) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.211444 [ 22866 ] {7382a2a3-30d7-4d86-a828-8514bd4e7efb} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.246418 [ 22865 ] {0185f63b-ac0b-49d7-9ed5-dc9ba1da4648} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42380) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.246684 [ 22865 ] {0185f63b-ac0b-49d7-9ed5-dc9ba1da4648} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.424705 [ 48599 ] {d0e9d73d-d34c-4075-9c46-eff43b06f888} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42440) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.424967 [ 48599 ] {d0e9d73d-d34c-4075-9c46-eff43b06f888} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.444409 [ 23587 ] {f670f74a-a4f7-4d39-97c8-7a74c3a2f037} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42484) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.444827 [ 23587 ] {f670f74a-a4f7-4d39-97c8-7a74c3a2f037} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.455124 [ 48631 ] {ebb9d77f-64c0-47fa-a620-b2885b30b40e} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42500) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.455374 [ 48631 ] {ebb9d77f-64c0-47fa-a620-b2885b30b40e} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.459003 [ 23601 ] {ce70bbdd-015d-4b04-94a3-616b2b613c3e} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42514) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.459274 [ 23601 ] {ce70bbdd-015d-4b04-94a3-616b2b613c3e} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.461003 [ 22865 ] {1573e0fd-1afe-4b63-b3f9-fad948973668} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42472) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.468756 [ 22865 ] {1573e0fd-1afe-4b63-b3f9-fad948973668} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.509282 [ 22865 ] {a2f00857-3e98-40d5-a81e-9a2583089f54} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42544) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.509585 [ 22865 ] {a2f00857-3e98-40d5-a81e-9a2583089f54} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.597442 [ 48599 ] {717a3ffb-4f32-4745-9285-4fedbbbd6afb} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42560) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.597682 [ 48599 ] {717a3ffb-4f32-4745-9285-4fedbbbd6afb} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.670544 [ 23587 ] {9ae1a26f-836b-4c45-bbbc-d77dc920bc50} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42598) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.670830 [ 23587 ] {9ae1a26f-836b-4c45-bbbc-d77dc920bc50} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.714247 [ 23587 ] {40e0d834-002f-42d8-840c-fb87f400cbd3} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42624) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.714647 [ 23587 ] {40e0d834-002f-42d8-840c-fb87f400cbd3} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.714815 [ 22858 ] {317bea0a-6603-4da2-aa73-ece1e8b945c9} executeQuery: Code: 341. DB::Exception: Log entry log-0000000193 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED) (version 24.3.12.76.altinitystable) (from [::1]:42092) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6751: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x00000000324a1232 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249b92b 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.715301 [ 22858 ] {317bea0a-6603-4da2-aa73-ece1e8b945c9} TCPHandler: Code: 341. DB::Exception: Log entry log-0000000193 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6751: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x00000000324a1232 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249b92b 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.719442 [ 48631 ] {d4212379-18fc-490f-95ed-9a580d5b060c} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42628) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.719773 [ 48631 ] {d4212379-18fc-490f-95ed-9a580d5b060c} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.725558 [ 23601 ] {26df95f4-45ae-4df3-828b-7dcdc8d29874} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42640) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.725865 [ 23601 ] {26df95f4-45ae-4df3-828b-7dcdc8d29874} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.738084 [ 64953 ] {931227f6-148c-4ee2-8ac4-d97de3231474} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:42646) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.738513 [ 64953 ] {931227f6-148c-4ee2-8ac4-d97de3231474} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.775615 [ 23601 ] {8a638beb-6437-46e4-aaf1-d4cf236a7ae8} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:42676) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:17.775927 [ 23601 ] {8a638beb-6437-46e4-aaf1-d4cf236a7ae8} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:18.660674 [ 766 ] {} test_ztc1o1yj.concurrent_optimize_table (4562fb62-2ac3-484f-8de5-067d7156d929): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3522: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000032459618 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f0fe371 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002f103012 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002f103e52 9. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 11. ? @ 0x00007fe1df9bbac3 12. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:18.738108 [ 12524 ] {c693d72f-899e-4c24-bee3-3e679afd90cf} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:43048) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:18.741932 [ 878 ] {} test_ztc1o1yj.concurrent_optimize_table (4562fb62-2ac3-484f-8de5-067d7156d929): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000323934e3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:254: DB::StorageReplicatedMergeTree::getZooKeeperAndAssertNotReadonly() const @ 0x00000000323932bc 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3757: DB::StorageReplicatedMergeTree::mergeSelectingTask()::$_0::operator()() const @ 0x000000003245e6de 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3877: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x000000003245d19a 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002f0fe371 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002f103012 10. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002f103e52 11. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:18.753155 [ 12524 ] {c693d72f-899e-4c24-bee3-3e679afd90cf} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:18.762057 [ 64953 ] {2113ae69-934e-4022-91a3-eb28e9955a3c} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:43070) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:18.762396 [ 64953 ] {2113ae69-934e-4022-91a3-eb28e9955a3c} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:18.769445 [ 23621 ] {1aa7b898-36e4-443e-b92d-773b0877948a} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:43082) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:18.769748 [ 23621 ] {1aa7b898-36e4-443e-b92d-773b0877948a} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:18.788025 [ 12524 ] {1962363e-bb2e-47b5-8f85-784b8df07090} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:43092) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:18.788255 [ 12524 ] {1962363e-bb2e-47b5-8f85-784b8df07090} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:18.814728 [ 23587 ] {8df8b6f3-fa21-40eb-ba71-66adac1ca85c} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:43106) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:18.815065 [ 23587 ] {8df8b6f3-fa21-40eb-ba71-66adac1ca85c} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:18.910241 [ 23587 ] {527ac51b-4cc1-4848-bb01-d5fc43214bac} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33456) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:18.910651 [ 23587 ] {527ac51b-4cc1-4848-bb01-d5fc43214bac} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:18.994153 [ 23621 ] {c608ffd6-75a9-466b-b304-7288fa59e6ab} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33508) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:18.994437 [ 23621 ] {c608ffd6-75a9-466b-b304-7288fa59e6ab} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.008484 [ 64953 ] {540984a4-aae1-47b1-a24b-fbbe807ac28a} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33526) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.008757 [ 64953 ] {540984a4-aae1-47b1-a24b-fbbe807ac28a} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.015190 [ 48611 ] {a2a26134-4425-433d-86e8-19e0c7f877bb} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33536) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.015486 [ 48611 ] {a2a26134-4425-433d-86e8-19e0c7f877bb} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.037586 [ 23621 ] {94ef9f1b-49a2-41f0-886a-3d5ef27999dc} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:33544) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.037863 [ 23621 ] {94ef9f1b-49a2-41f0-886a-3d5ef27999dc} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.069831 [ 64953 ] {4f748398-9006-4161-b19d-94e0d7c90be7} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33572) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.070180 [ 64953 ] {4f748398-9006-4161-b19d-94e0d7c90be7} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.157644 [ 64953 ] {432d0031-fb5b-43f9-97d8-49dde1dd0745} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33578) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.157932 [ 64953 ] {432d0031-fb5b-43f9-97d8-49dde1dd0745} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.248114 [ 81468 ] {5047a0c2-8892-4187-bd86-a1dbcfabe842} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33616) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.248538 [ 81468 ] {5047a0c2-8892-4187-bd86-a1dbcfabe842} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.267026 [ 48611 ] {39913d0c-4e23-41af-9a01-228aa55e9b7d} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33636) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.267272 [ 48611 ] {39913d0c-4e23-41af-9a01-228aa55e9b7d} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.274474 [ 64953 ] {c2cc7089-d3ad-4e1c-9ea9-1c06532e39a0} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33642) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.274843 [ 64953 ] {c2cc7089-d3ad-4e1c-9ea9-1c06532e39a0} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.309294 [ 23611 ] {84631255-fd7b-4c08-ad01-68a575fa6998} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:33658) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.309753 [ 23611 ] {84631255-fd7b-4c08-ad01-68a575fa6998} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.309896 [ 23498 ] {9d20869e-d79e-4238-9fb9-ec57732c50db} executeQuery: Code: 57. DB::Exception: Table test_qij55zdv.aine already exists. (TABLE_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:33670) (comment: 01073_attach_if_not_exists.sql) (in query: ATTACH TABLE aine;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cf1bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.310025 [ 23498 ] {9d20869e-d79e-4238-9fb9-ec57732c50db} TCPHandler: Code: 57. DB::Exception: Table test_qij55zdv.aine already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cf1bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.356955 [ 64953 ] {36e6ab5f-cd63-4360-82b4-7d200863ceea} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33678) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.357215 [ 64953 ] {36e6ab5f-cd63-4360-82b4-7d200863ceea} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.369080 [ 48611 ] {a19c8059-444d-4b84-a265-5c6be2a6eee7} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33694) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.369321 [ 48611 ] {a19c8059-444d-4b84-a265-5c6be2a6eee7} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.500861 [ 23498 ] {0fd32d35-604e-4e9f-a8d8-4adebe2e5a2f} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 24.3.12.76.altinitystable) (from [::1]:33730) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 12140, min_bytes_for_wide_part = 738974781, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 221219333, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 14720769, merge_max_block_size = 21094, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5457841591, index_granularity_bytes = 944329, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 87605, primary_key_compress_block_size = 73615), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.501205 [ 23498 ] {0fd32d35-604e-4e9f-a8d8-4adebe2e5a2f} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&) @ 0x00000000323ab8b6 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:546: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000032399c21 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageReplicatedMergeTree* std::construct_at[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, DB::StorageReplicatedMergeTree*>(DB::StorageReplicatedMergeTree*, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000033075f41 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&>(std::allocator, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307584e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003307557b 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:726: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306d742 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.502231 [ 23622 ] {ef52fe1a-2f0e-4439-9276-d8d778fd86c4} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33758) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.502491 [ 23622 ] {ef52fe1a-2f0e-4439-9276-d8d778fd86c4} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.513686 [ 3522 ] {39dcfc48-cd5e-4ac7-8055-45b73de30115} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33772) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.514039 [ 3522 ] {39dcfc48-cd5e-4ac7-8055-45b73de30115} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.531527 [ 14974 ] {c65c1ba8-6a50-4f0d-9adc-8cfac97e2a88} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33786) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.531841 [ 14974 ] {c65c1ba8-6a50-4f0d-9adc-8cfac97e2a88} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.610932 [ 3522 ] {91925c43-9516-4d04-bf8d-dd2d6bc4806c} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33804) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.611201 [ 3522 ] {91925c43-9516-4d04-bf8d-dd2d6bc4806c} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.717038 [ 3522 ] {34cbd7de-b2e1-4828-a296-b017ce384aa2} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33836) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.717286 [ 3522 ] {34cbd7de-b2e1-4828-a296-b017ce384aa2} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.740132 [ 14974 ] {e769cb1d-c4d3-4630-b5f6-b0528489bb3b} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33864) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.740411 [ 14974 ] {e769cb1d-c4d3-4630-b5f6-b0528489bb3b} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.747035 [ 81460 ] {b1f81e92-8959-461f-a41f-1bc71689bf5f} executeQuery: Code: 341. DB::Exception: Log entry log-0000000162 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED) (version 24.3.12.76.altinitystable) (from [::1]:43004) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6751: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x00000000324a1232 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249b92b 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.747273 [ 81460 ] {b1f81e92-8959-461f-a41f-1bc71689bf5f} TCPHandler: Code: 341. DB::Exception: Log entry log-0000000162 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6751: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x00000000324a1232 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003249b92b 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000031787138 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 10. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.778012 [ 23562 ] {31559df3-d8dd-4dfe-80d2-6426665744e1} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33886) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.778289 [ 23562 ] {31559df3-d8dd-4dfe-80d2-6426665744e1} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.780335 [ 23610 ] {c5d7c75f-bf96-4e3d-8c5a-3e034a247fa7} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33890) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.780624 [ 23610 ] {c5d7c75f-bf96-4e3d-8c5a-3e034a247fa7} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.813623 [ 3522 ] {87ab1f4e-8956-4613-95df-514c36204445} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33902) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.813856 [ 3522 ] {87ab1f4e-8956-4613-95df-514c36204445} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.859969 [ 3522 ] {689e00e3-5ff3-46fb-b88d-b0aab6262dc7} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:33916) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:19.860302 [ 3522 ] {689e00e3-5ff3-46fb-b88d-b0aab6262dc7} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.054233 [ 23562 ] {87b06a14-068d-4954-86eb-c1a5896cdfdb} executeQuery: Code: 218. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table is dropped or detached. (TABLE_IS_DROPPED) (version 24.3.12.76.altinitystable) (from [::1]:33992) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Storages/IStorage.cpp:64: DB::IStorage::lockForShare(String const&, std::chrono::duration> const&) @ 0x00000000320dd146 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033c9ef7a 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.054522 [ 23562 ] {87b06a14-068d-4954-86eb-c1a5896cdfdb} TCPHandler: Code: 218. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table is dropped or detached. (TABLE_IS_DROPPED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002152bb4a 4. ./build_docker/./src/Storages/IStorage.cpp:64: DB::IStorage::lockForShare(String const&, std::chrono::duration> const&) @ 0x00000000320dd146 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000033c9ef7a 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000030f342be 7. ./contrib/llvm-project/libcxx/include/vector:1595: DB::InterpreterInsertQuery::execute() @ 0x0000000030f384c3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.066020 [ 3522 ] {f60b67c6-9d2a-4b40-a36d-27d183df3ced} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 24.3.12.76.altinitystable) (from [::1]:33978) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.068426 [ 3522 ] {f60b67c6-9d2a-4b40-a36d-27d183df3ced} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_ztc1o1yj/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:799: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda1'()::operator()() const @ 0x0000000033035e89 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1052: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda2'()::operator()() const @ 0x0000000033031cf1 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1087: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()::operator()() const @ 0x0000000033031b77 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool)::'lambda3'()&&)::'lambda'()&&) @ 0x00000000330317d8 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1102: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long, bool) @ 0x0000000033015ffb 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:444: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000033001343 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk) @ 0x0000000033012ec7 11. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:0: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000033d09f35 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 18. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 19. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 20. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.071475 [ 23635 ] {8b0195a8-c274-4b4a-9dfc-135b7d183f77} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:34004) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.071785 [ 23635 ] {8b0195a8-c274-4b4a-9dfc-135b7d183f77} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.100918 [ 23562 ] {6ae94b83-a589-41b1-b549-849c28312d9c} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:34012) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.101254 [ 23562 ] {6ae94b83-a589-41b1-b549-849c28312d9c} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.106085 [ 23610 ] {6c5dccda-7f78-40a8-be1f-21776caecbcd} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:34024) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.106316 [ 23610 ] {6c5dccda-7f78-40a8-be1f-21776caecbcd} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000317867ea 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.344990 [ 23597 ] {a4d99780-f378-460f-a1a8-050e452c5b98} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:34118) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.345242 [ 23597 ] {a4d99780-f378-460f-a1a8-050e452c5b98} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.348590 [ 81471 ] {afd1922f-5eae-42e0-98d6-6e0ee1a58123} executeQuery: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:34132) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.348907 [ 81471 ] {afd1922f-5eae-42e0-98d6-6e0ee1a58123} TCPHandler: Code: 60. DB::Exception: Table test_ztc1o1yj.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002f7e7441 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:429: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002fd85a40 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002fd8cedb 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000030f304b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:406: DB::InterpreterInsertQuery::execute() @ 0x0000000030f35bb6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.495409 [ 48603 ] {14786208-d81d-4d8c-a3cc-fc6a83d3b022} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:34156). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:34156) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::TCPHandler::runImpl() @ 0x0000000033487bf2 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.495638 [ 48603 ] {14786208-d81d-4d8c-a3cc-fc6a83d3b022} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:34156). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:20.495678 [ 48603 ] {14786208-d81d-4d8c-a3cc-fc6a83d3b022} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:34156). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::TCPHandler::runImpl() @ 0x0000000033487bf2 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.495780 [ 48603 ] {14786208-d81d-4d8c-a3cc-fc6a83d3b022} TCPHandler: Client has gone away. 2025.03.05 21:16:20.506661 [ 23642 ] {d7c53061-ff7d-4e16-b4b2-47fca5bd179b} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:34154). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::1]:34154) (comment: 01103_optimize_drop_race_zookeeper.sh) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::TCPHandler::runImpl() @ 0x0000000033487bf2 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.506881 [ 23642 ] {d7c53061-ff7d-4e16-b4b2-47fca5bd179b} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:34154). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x00000000334a76a3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:270: DB::TCPHandler::runImpl() @ 0x00000000334876b9 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:20.506911 [ 23642 ] {d7c53061-ff7d-4e16-b4b2-47fca5bd179b} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:34154). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000024883d67 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000024882f1f 5. DB::WriteBuffer::next() @ 0x000000001807b36c 6. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::TCPHandler::sendProfileEvents() @ 0x00000000334b1c38 7. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::TCPHandler::runImpl() @ 0x0000000033487bf2 8. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 12. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 13. ? @ 0x00007fe1df9bbac3 14. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.507048 [ 23642 ] {d7c53061-ff7d-4e16-b4b2-47fca5bd179b} TCPHandler: Client has gone away. 2025.03.05 21:16:20.672577 [ 23597 ] {aec210ec-0911-4f99-8628-8026572148b7} executeQuery: Code: 72. DB::Exception: Cannot parse exponent while reading decimal: Cannot parse Decimal(9, 1) from String: In scope SELECT toDecimal32('e', 1). (CANNOT_PARSE_NUMBER) (version 24.3.12.76.altinitystable) (from [::1]:34264) (comment: 01070_to_decimal_or_null_exception.sql) (in query: SELECT toDecimal32('e', 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./src/IO/readDecimalText.h:124: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x000000002f129e1d 5. ./src/IO/readDecimalText.h:162: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f527db4 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5d99ec 7. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000185e5f42 8. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000185dd28d 9. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185ce50f 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 14. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:16:20.672883 [ 23597 ] {aec210ec-0911-4f99-8628-8026572148b7} TCPHandler: Code: 72. DB::Exception: Cannot parse exponent while reading decimal: Cannot parse Decimal(9, 1) from String: In scope SELECT toDecimal32('e', 1). (CANNOT_PARSE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./src/IO/readDecimalText.h:124: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x000000002f129e1d 5. ./src/IO/readDecimalText.h:162: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f527db4 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5d99ec 7. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000185e5f42 8. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000185dd28d 9. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185ce50f 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 14. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:16:20.703376 [ 23597 ] {d46f596c-9cd0-4563-9c81-cbb801d702ad} executeQuery: Code: 72. DB::Exception: Cannot parse exponent while reading decimal: Cannot parse Decimal(18, 2) from String: In scope SELECT toDecimal64('e', 2). (CANNOT_PARSE_NUMBER) (version 24.3.12.76.altinitystable) (from [::1]:34264) (comment: 01070_to_decimal_or_null_exception.sql) (in query: SELECT toDecimal64('e', 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./src/IO/readDecimalText.h:124: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x000000002f12a87d 5. ./src/IO/readDecimalText.h:162: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f528818 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5db7ca 7. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000018602d24 8. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000185fa044 9. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185eb52f 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 14. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:16:20.703626 [ 23597 ] {d46f596c-9cd0-4563-9c81-cbb801d702ad} TCPHandler: Code: 72. DB::Exception: Cannot parse exponent while reading decimal: Cannot parse Decimal(18, 2) from String: In scope SELECT toDecimal64('e', 2). (CANNOT_PARSE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./src/IO/readDecimalText.h:124: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x000000002f12a87d 5. ./src/IO/readDecimalText.h:162: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f528818 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5db7ca 7. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal64, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000018602d24 8. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000185fa044 9. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal64, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185eb52f 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 14. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:16:20.732371 [ 23597 ] {fbb9adda-44f6-4446-a717-486dfb2e01ec} executeQuery: Code: 72. DB::Exception: Cannot parse exponent while reading decimal: Cannot parse Decimal(38, 3) from String: In scope SELECT toDecimal128('e', 3). (CANNOT_PARSE_NUMBER) (version 24.3.12.76.altinitystable) (from [::1]:34264) (comment: 01070_to_decimal_or_null_exception.sql) (in query: SELECT toDecimal128('e', 3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./src/IO/readDecimalText.h:124: bool DB::readDigits>>(DB::ReadBuffer&, DB::Decimal>&, unsigned int&, int&, bool) @ 0x000000002f12b2dd 5. ./src/IO/readDecimalText.h:162: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x000000002f529216 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5dd217 7. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000018620202 8. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000186174ed 9. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000186083ef 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 14. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:16:20.732676 [ 23597 ] {fbb9adda-44f6-4446-a717-486dfb2e01ec} TCPHandler: Code: 72. DB::Exception: Cannot parse exponent while reading decimal: Cannot parse Decimal(38, 3) from String: In scope SELECT toDecimal128('e', 3). (CANNOT_PARSE_NUMBER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./src/IO/readDecimalText.h:124: bool DB::readDigits>>(DB::ReadBuffer&, DB::Decimal>&, unsigned int&, int&, bool) @ 0x000000002f12b2dd 5. ./src/IO/readDecimalText.h:162: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x000000002f529216 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5dd217 7. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>>, DB::(anonymous namespace)::NameToDecimal128, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000018620202 8. bool DB::callOnIndexAndDataType>>, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000186174ed 9. DB::(anonymous namespace)::FunctionConvert>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000186083ef 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 12. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 14. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:16:20.935930 [ 3522 ] {77c011d1-591c-4151-bb76-fcc2142fc6f1} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (16) of function h3ToChildren is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3ToChildren(599405990164561919, 16). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:34324) (comment: 01070_h3_to_children.sql) (in query: SELECT h3ToChildren(599405990164561919, 16);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::(anonymous namespace)::FunctionH3ToChildren::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd70332 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:16:20.936256 [ 3522 ] {77c011d1-591c-4151-bb76-fcc2142fc6f1} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (16) of function h3ToChildren is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3ToChildren(599405990164561919, 16). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. DB::(anonymous namespace)::FunctionH3ToChildren::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd70332 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:16:20.981842 [ 3522 ] {cb1b2160-ffb0-4269-9ee5-ffadf757ce2d} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_table_for_01070_exception_code_in_query_log_table' in scope SELECT * FROM test_table_for_01070_exception_code_in_query_log_table. (UNKNOWN_TABLE) (version 24.3.12.76.altinitystable) (from [::1]:34352) (comment: 01070_exception_code_in_query_log_table.sql) (in query: SELECT * FROM test_table_for_01070_exception_code_in_query_log_table;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:20.982085 [ 3522 ] {cb1b2160-ffb0-4269-9ee5-ffadf757ce2d} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_table_for_01070_exception_code_in_query_log_table' in scope SELECT * FROM test_table_for_01070_exception_code_in_query_log_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308779ae 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 6. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 15. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 20. ? @ 0x00007fe1df9bbac3 21. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:21.763186 [ 48606 ] {92974f11-644c-48ed-9877-06c0ed3e7ce4} ReadWriteBufferFromHTTP: Failed to make request to 'http://127.0.0.1:9018/ping?use_connection_pooling=1'. Error: 'Connection refused'. Failed at try 10/10. 2025.03.05 21:16:21.808123 [ 23620 ] {0be98d66-b5bc-47db-93b5-bbf3b00943a1} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 1 ('BADREQUEST'): BADREQUEST . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:33686) (comment: 01071_http_header_exception_code.sh) (in query: BADREQUEST ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:21.808310 [ 23620 ] {0be98d66-b5bc-47db-93b5-bbf3b00943a1} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 1 ('BADREQUEST'): BADREQUEST . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:22.669422 [ 3522 ] {041b6c4b-bd03-484a-b2ea-267766c94a78} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'value' in scope SELECT sum(value) FROM test_alter_on_mutation. Maybe you meant: ['value1']. (UNKNOWN_IDENTIFIER) (version 24.3.12.76.altinitystable) (from [::1]:34760) (comment: 01062_alter_on_mutataion_zookeeper_long.sql) (in query: SELECT sum(value) from test_alter_on_mutation;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:22.669586 [ 3522 ] {041b6c4b-bd03-484a-b2ea-267766c94a78} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'value' in scope SELECT sum(value) FROM test_alter_on_mutation. Maybe you meant: ['value1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x000000003092d3f3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030884cf5 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 7. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 10. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:24.891682 [ 48603 ] {3e7833f8-be25-4249-ba76-369a03781859} executeQuery: Code: 80. DB::Exception: Cannot CREATE a table AS test_xsryss1d.v, it is a View. (INCORRECT_QUERY) (version 24.3.12.76.altinitystable) (from [::1]:35290) (comment: 01056_create_table_as.sql) (in query: CREATE TABLE t3 AS v;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000307bab58 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b4cdf 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:24.891877 [ 48603 ] {3e7833f8-be25-4249-ba76-369a03781859} TCPHandler: Code: 80. DB::Exception: Cannot CREATE a table AS test_xsryss1d.v, it is a View. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000307bab58 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b4cdf 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:24.919386 [ 48603 ] {9a67366b-60d3-4609-b3cb-154510f00b13} executeQuery: Code: 80. DB::Exception: Cannot CREATE a table AS test_xsryss1d.dict, it is a Dictionary. (INCORRECT_QUERY) (version 24.3.12.76.altinitystable) (from [::1]:35290) (comment: 01056_create_table_as.sql) (in query: CREATE TABLE t3 AS dict;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000307bad38 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b4cdf 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:24.919563 [ 48603 ] {9a67366b-60d3-4609-b3cb-154510f00b13} TCPHandler: Code: 80. DB::Exception: Cannot CREATE a table AS test_xsryss1d.dict, it is a Dictionary. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000307bad38 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&) const @ 0x00000000307b4cdf 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1224: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307bfc7d 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:27.859167 [ 81473 ] {22bca28d-6786-448c-868d-e16bed94014e} executeQuery: Code: 264. DB::Exception: Table test_gwe7v9h7.left_join (958d073f-92e9-4c5f-8510-8a9203efa474) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.3.12.76.altinitystable) (from [::1]:35666) (comment: 01051_all_join_engine.sql) (in query: SELECT * FROM t1 LEFT JOIN left_join j USING(x) ORDER BY x, str, s;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageJoin.cpp:0: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x000000003224a047 5. ./build_docker/./src/Planner/PlannerJoins.cpp:867: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000310991d5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:27.859522 [ 81473 ] {22bca28d-6786-448c-868d-e16bed94014e} TCPHandler: Code: 264. DB::Exception: Table test_gwe7v9h7.left_join (958d073f-92e9-4c5f-8510-8a9203efa474) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageJoin.cpp:0: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x000000003224a047 5. ./build_docker/./src/Planner/PlannerJoins.cpp:867: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000310991d5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:27.863728 [ 81473 ] {15ebb4d0-a565-477a-bd65-ca61a43ed8ff} executeQuery: Code: 264. DB::Exception: Table test_gwe7v9h7.full_join (eb61ada6-7a81-4922-81a4-3a9eff0cf5d2) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.3.12.76.altinitystable) (from [::1]:35666) (comment: 01051_all_join_engine.sql) (in query: SELECT * FROM t1 FULL JOIN full_join j USING(x) ORDER BY x, str, s;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageJoin.cpp:0: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x000000003224a047 5. ./build_docker/./src/Planner/PlannerJoins.cpp:867: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000310991d5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:27.863836 [ 81473 ] {15ebb4d0-a565-477a-bd65-ca61a43ed8ff} TCPHandler: Code: 264. DB::Exception: Table test_gwe7v9h7.full_join (eb61ada6-7a81-4922-81a4-3a9eff0cf5d2) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageJoin.cpp:0: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x000000003224a047 5. ./build_docker/./src/Planner/PlannerJoins.cpp:867: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000310991d5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:27.933635 [ 81473 ] {caff746e-1675-42da-9925-b59cc3e9baef} executeQuery: Code: 264. DB::Exception: Table test_gwe7v9h7.left_join (8d4ffed1-9cef-4205-b9a1-217c3744a0c8) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.3.12.76.altinitystable) (from [::1]:35666) (comment: 01051_all_join_engine.sql) (in query: SELECT * FROM t1 LEFT JOIN left_join j USING(x) ORDER BY x, str, s;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageJoin.cpp:0: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x000000003224a047 5. ./build_docker/./src/Planner/PlannerJoins.cpp:867: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000310991d5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:27.933738 [ 81473 ] {caff746e-1675-42da-9925-b59cc3e9baef} TCPHandler: Code: 264. DB::Exception: Table test_gwe7v9h7.left_join (8d4ffed1-9cef-4205-b9a1-217c3744a0c8) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageJoin.cpp:0: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x000000003224a047 5. ./build_docker/./src/Planner/PlannerJoins.cpp:867: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000310991d5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:27.935633 [ 81473 ] {2a8e4584-6577-4457-b8b8-b026d0b8823a} executeQuery: Code: 264. DB::Exception: Table test_gwe7v9h7.full_join (1fe038be-e796-4c62-9f57-b52b49d899b6) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.3.12.76.altinitystable) (from [::1]:35666) (comment: 01051_all_join_engine.sql) (in query: SELECT * FROM t1 FULL JOIN full_join j USING(x) ORDER BY x, str, s;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageJoin.cpp:0: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x000000003224a047 5. ./build_docker/./src/Planner/PlannerJoins.cpp:867: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000310991d5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:27.935740 [ 81473 ] {2a8e4584-6577-4457-b8b8-b026d0b8823a} TCPHandler: Code: 264. DB::Exception: Table test_gwe7v9h7.full_join (1fe038be-e796-4c62-9f57-b52b49d899b6) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Storages/StorageJoin.cpp:0: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x000000003224a047 5. ./build_docker/./src/Planner/PlannerJoins.cpp:867: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000310991d5 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 7. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 14. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 19. ? @ 0x00007fe1df9bbac3 20. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:27.972070 [ 5913 ] {} ExternalDictionaries: Could not update cache dictionary 'one_cell_cache_ints', next update is scheduled at 2025-03-05 21:16:32: Code: 81. DB::Exception: Database test_01054 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a6bd 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x00000000308a1073 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089c809 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6962: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086fd78 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:171: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000029011cf3 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000002901238a 20. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029501ec9 21. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:28.008953 [ 23642 ] {24943c6f-43c7-4e03-b7ec-a102f8f97757} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a6bd 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x00000000308a1073 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089c809 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6962: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086fd78 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:171: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000029011cf3 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000002901238a 20. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029501ec9 21. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(61)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:35730) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(61));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.008993 [ 48624 ] {9a12ad52-550b-44ff-bc87-ab2db290ead2} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(79)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:35764) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(79));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.009022 [ 48603 ] {d85638fe-c895-4eb9-be13-d2851780e693} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(34)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:35736) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(34));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.009034 [ 14973 ] {04abeaa5-91cf-420e-bf58-d82542570bfa} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(79)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:35746) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(79));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.009430 [ 23642 ] {24943c6f-43c7-4e03-b7ec-a102f8f97757} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a6bd 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x00000000308a1073 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089c809 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6962: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086fd78 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:171: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000029011cf3 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000002901238a 20. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029501ec9 21. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(61)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.009473 [ 48624 ] {9a12ad52-550b-44ff-bc87-ab2db290ead2} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(79)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.009557 [ 14973 ] {04abeaa5-91cf-420e-bf58-d82542570bfa} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(79)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.009563 [ 48603 ] {d85638fe-c895-4eb9-be13-d2851780e693} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(34)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.383042 [ 48598 ] {c9dab4b0-fb14-4e64-9427-4a593cb32922} DynamicQueryHandler: Code: 246. DB::Exception: Can't decompress data: header is corrupt with compressed block size 0. (CORRUPTED_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Compression/ICompressionCodec.cpp:117: DB::ICompressionCodec::readCompressedBlockSize(char const*) const @ 0x000000002f3d654e 5. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:143: DB::readHeaderAndGetCodecAndSize(char const*, char8_t, std::shared_ptr&, unsigned long&, unsigned long&, bool, bool) @ 0x000000002f379bea 6. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002f378b96 7. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:12: DB::CompressedReadBuffer::nextImpl() @ 0x000000002f377b46 8. DB::ReadBuffer::next() @ 0x0000000018778250 9. ./build_docker/./src/IO/ReadBuffer.cpp:28: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000002f0bf113 10. DB::ReadBuffer::next() @ 0x0000000018778250 11. ./src/IO/ConcatReadBuffer.h:81: DB::ConcatReadBuffer::nextImpl() @ 0x000000002fc149b4 12. DB::ReadBuffer::next() @ 0x0000000018778250 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x00000000317022e2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 15. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:28.422102 [ 730 ] {0389859f-588a-4b5b-9062-724bd371346a} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(41)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:35882) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(41));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.422473 [ 730 ] {0389859f-588a-4b5b-9062-724bd371346a} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(41)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.447500 [ 730 ] {b5002abd-2cba-4869-8ad9-b7f4613196db} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(30)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:35886) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(30));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.447841 [ 730 ] {b5002abd-2cba-4869-8ad9-b7f4613196db} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(30)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.448333 [ 48614 ] {440962eb-8981-4b64-a432-c72d684c8a81} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(45)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:35888) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(45));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.448673 [ 48614 ] {440962eb-8981-4b64-a432-c72d684c8a81} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(45)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.465306 [ 48598 ] {27094e2d-861d-4aa6-816a-2e0bdff3d674} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(48)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:35902) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(48));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.465616 [ 48598 ] {27094e2d-861d-4aa6-816a-2e0bdff3d674} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(48)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.800715 [ 11415 ] {48ae5f11-cead-43e4-81b0-8c9ad5b45f38} ExternalDictionariesLoader: Could not load external dictionary '237b9c58-4b27-41f8-96a2-38538b12c1d5', next update is scheduled at 2025-03-05 21:16:34: Code: 482. DB::Exception: Dictionaries with executable dictionary source are not allowed to be created from DDL query. (DICTIONARY_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Dictionaries/ExecutableDictionarySource.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>::__call_impl (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>>(std::__function::__policy_storage const*, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr&&, String const&, bool) @ 0x00000000290888a9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e834b9b 6. ./build_docker/./src/Dictionaries/DictionarySourceFactory.cpp:0: DB::DictionarySourceFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, DB::DictionaryStructure const&, std::shared_ptr, String const&, bool) const @ 0x000000002e83431f 7. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830492 8. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 12. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:28.801341 [ 48581 ] {48ae5f11-cead-43e4-81b0-8c9ad5b45f38} executeQuery: Code: 482. DB::Exception: Dictionaries with executable dictionary source are not allowed to be created from DDL query: In scope SELECT dictGetString(concat('test_bd79uq7p', '.restricted_dict'), 'value', toUInt64(1)). (DICTIONARY_ACCESS_DENIED) (version 24.3.12.76.altinitystable) (from [::1]:35964) (comment: 01045_dictionaries_restrictions.sql) (in query: SELECT dictGetString(concat('test_bd79uq7p', '.restricted_dict'), 'value', toUInt64(1))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Dictionaries/ExecutableDictionarySource.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>::__call_impl (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>>(std::__function::__policy_storage const*, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr&&, String const&, bool) @ 0x00000000290888a9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e834b9b 6. ./build_docker/./src/Dictionaries/DictionarySourceFactory.cpp:0: DB::DictionarySourceFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, DB::DictionaryStructure const&, std::shared_ptr, String const&, bool) const @ 0x000000002e83431f 7. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830492 8. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 12. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:28.801501 [ 48581 ] {48ae5f11-cead-43e4-81b0-8c9ad5b45f38} TCPHandler: Code: 482. DB::Exception: Dictionaries with executable dictionary source are not allowed to be created from DDL query: In scope SELECT dictGetString(concat('test_bd79uq7p', '.restricted_dict'), 'value', toUInt64(1)). (DICTIONARY_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Dictionaries/ExecutableDictionarySource.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>::__call_impl (DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr, String const&, bool)>>(std::__function::__policy_storage const*, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, DB::Block&, std::shared_ptr&&, String const&, bool) @ 0x00000000290888a9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002e834b9b 6. ./build_docker/./src/Dictionaries/DictionarySourceFactory.cpp:0: DB::DictionarySourceFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, DB::DictionaryStructure const&, std::shared_ptr, String const&, bool) const @ 0x000000002e83431f 7. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002e830492 8. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:42: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x0000000030394402 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1040: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000303a94c6 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000303a74a2 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000303af029 12. ./contrib/llvm-project/libcxx/include/tuple:1789: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000303aed07 13. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:28.829033 [ 22860 ] {41afe3ad-19ae-4590-b917-8073f5642c14} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(54)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:35976) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(54));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.829380 [ 22860 ] {41afe3ad-19ae-4590-b917-8073f5642c14} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(54)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.852545 [ 48581 ] {d5e1a642-770a-40e1-a7fc-9a4ef5336378} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(15)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:35980) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(15));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.852891 [ 48581 ] {d5e1a642-770a-40e1-a7fc-9a4ef5336378} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(15)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.860176 [ 22860 ] {b0e25d4d-d024-4bee-969a-ea5472b0beac} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(10)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:35996) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(10));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.860471 [ 22860 ] {b0e25d4d-d024-4bee-969a-ea5472b0beac} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(10)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.890565 [ 48581 ] {31398f3b-cc19-4c91-93c8-3205f84d68ef} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(69)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:36004) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(69));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:28.890865 [ 48581 ] {31398f3b-cc19-4c91-93c8-3205f84d68ef} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(69)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:29.118167 [ 48581 ] {2f59ba15-15a3-40f0-85ce-1cfbbae34e1c} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 2 of function h3kRing. Must be unsigned native integer.: In scope SELECT h3kRing(581276613233082367, -1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:52068) (comment: 01042_h3_k_ring.sql) (in query: SELECT h3kRing(581276613233082367, -1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000001baf9135 4. DB::(anonymous namespace)::FunctionH3KRing::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cd7c67f 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:29.118661 [ 48581 ] {2f59ba15-15a3-40f0-85ce-1cfbbae34e1c} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 2 of function h3kRing. Must be unsigned native integer.: In scope SELECT h3kRing(581276613233082367, -1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000001baf9135 4. DB::(anonymous namespace)::FunctionH3KRing::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cd7c67f 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:29.146640 [ 48581 ] {92a847aa-0b57-4281-8116-436269556a5c} executeQuery: Code: 12. DB::Exception: Too large 'k' argument for h3kRing function, maximum 10000: In scope SELECT h3kRing(581276613233082367, toUInt16(-1)). (PARAMETER_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:52068) (comment: 01042_h3_k_ring.sql) (in query: SELECT h3kRing(581276613233082367, toUInt16(-1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int const&) @ 0x000000001cd59192 4. DB::(anonymous namespace)::FunctionH3KRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd7b80e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:16:29.148161 [ 48581 ] {92a847aa-0b57-4281-8116-436269556a5c} TCPHandler: Code: 12. DB::Exception: Too large 'k' argument for h3kRing function, maximum 10000: In scope SELECT h3kRing(581276613233082367, toUInt16(-1)). (PARAMETER_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int const&) @ 0x000000001cd59192 4. DB::(anonymous namespace)::FunctionH3KRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd7b80e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 9. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 13. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 16. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:16:29.154171 [ 48581 ] {a347b657-3f8b-4d9d-976d-07b0feaa1395} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 2 of function h3kRing. Must be unsigned native integer.: In scope SELECT h3kRing(581276613233082367, -1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:52068) (comment: 01042_h3_k_ring.sql) (in query: SELECT h3kRing(581276613233082367, -1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000001baf9135 4. DB::(anonymous namespace)::FunctionH3KRing::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cd7c67f 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:29.160443 [ 48581 ] {a347b657-3f8b-4d9d-976d-07b0feaa1395} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 2 of function h3kRing. Must be unsigned native integer.: In scope SELECT h3kRing(581276613233082367, -1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000001baf9135 4. DB::(anonymous namespace)::FunctionH3KRing::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001cd7c67f 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:29.240364 [ 48581 ] {717c5f89-b0d8-4b80-bf7e-35ea9e5a7e67} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(67)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52126) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(67));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:29.240743 [ 48581 ] {717c5f89-b0d8-4b80-bf7e-35ea9e5a7e67} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(67)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:29.281514 [ 48581 ] {24e33647-6cbc-4fe6-b193-60cae9a4de75} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(76)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52140) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(76));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:29.281795 [ 48581 ] {24e33647-6cbc-4fe6-b193-60cae9a4de75} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(76)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:29.294295 [ 22860 ] {d71d4f9e-a395-4c16-b51c-2a121eea6cd8} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(49)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52154) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(49));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:29.294582 [ 22860 ] {d71d4f9e-a395-4c16-b51c-2a121eea6cd8} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(49)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:29.300070 [ 48602 ] {d8e11368-0e49-4195-94c4-f263286eec23} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(31)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52156) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(31));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:29.300365 [ 48602 ] {d8e11368-0e49-4195-94c4-f263286eec23} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(31)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:29.652107 [ 48581 ] {dfeda63b-1d2f-47c0-8fd2-828de332b212} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(75)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52210) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(75));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:29.652475 [ 48581 ] {dfeda63b-1d2f-47c0-8fd2-828de332b212} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(75)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:29.708218 [ 48581 ] {b612cbce-602c-4a2f-80b3-5c9d07c4ba75} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(13)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52226) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(13));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:29.708819 [ 48581 ] {b612cbce-602c-4a2f-80b3-5c9d07c4ba75} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(13)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:29.719326 [ 48602 ] {255a14bc-3f2b-46ab-81d5-3bb59cd2e7a9} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(61)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52238) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(61));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:29.719720 [ 48602 ] {255a14bc-3f2b-46ab-81d5-3bb59cd2e7a9} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(61)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:29.752942 [ 48581 ] {44447510-7d9c-4386-83b2-4c5c346c4a3a} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(33)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52254) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(33));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:29.753574 [ 48581 ] {44447510-7d9c-4386-83b2-4c5c346c4a3a} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(33)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:30.115213 [ 48581 ] {d27b6d75-dda0-4041-8439-09084655de20} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(41)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52306) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(41));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:30.115569 [ 48581 ] {d27b6d75-dda0-4041-8439-09084655de20} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(41)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:30.133043 [ 22860 ] {d85f1884-b0fb-4c41-baa9-f21e4700b98e} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(70)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52316) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(70));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:30.133317 [ 22860 ] {d85f1884-b0fb-4c41-baa9-f21e4700b98e} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(70)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:30.152055 [ 48581 ] {9e8fc7a7-ddc3-4c2f-b8da-e27c4cc0a92d} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(93)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52326) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(93));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:30.152314 [ 48581 ] {9e8fc7a7-ddc3-4c2f-b8da-e27c4cc0a92d} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(93)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:30.220204 [ 48581 ] {8cd30036-4ffe-440c-9476-bfc77092ea3f} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(26)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52328) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(26));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:30.220511 [ 48581 ] {8cd30036-4ffe-440c-9476-bfc77092ea3f} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(26)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:30.550877 [ 48581 ] {97fadf3b-315e-45f1-864b-2dc2eb5162b2} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(31)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52386) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(31));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:30.551199 [ 48581 ] {97fadf3b-315e-45f1-864b-2dc2eb5162b2} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(31)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:30.572467 [ 48581 ] {7635029d-01de-44d8-8d27-a4dd2544fb02} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(76)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52416) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(76));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:30.572758 [ 48581 ] {7635029d-01de-44d8-8d27-a4dd2544fb02} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(76)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:30.618435 [ 48581 ] {cf8a6ce0-cee9-490a-9ccd-a14414593d0c} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(33)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52424) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(33));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:30.618826 [ 48581 ] {cf8a6ce0-cee9-490a-9ccd-a14414593d0c} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(33)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:30.631880 [ 22860 ] {05df449c-743b-422a-b235-6d62b32da55b} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(94)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52432) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(94));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:30.632234 [ 22860 ] {05df449c-743b-422a-b235-6d62b32da55b} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(94)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.006554 [ 48602 ] {c7b5ab28-92fd-433e-acc9-5714de91b379} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(9)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52530) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(9));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.007176 [ 48602 ] {c7b5ab28-92fd-433e-acc9-5714de91b379} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(9)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.022653 [ 14920 ] {e93ee319-1097-4ae2-bf4c-8a9b97e9bfe2} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(52)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52558) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(52));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.022983 [ 14920 ] {e93ee319-1097-4ae2-bf4c-8a9b97e9bfe2} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(52)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.052875 [ 22860 ] {d3730ab3-ba6a-4fbe-bc61-b0c549948daf} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(52)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52582) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(52));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.053237 [ 22860 ] {d3730ab3-ba6a-4fbe-bc61-b0c549948daf} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(52)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.055129 [ 48602 ] {12bd2f03-8deb-4510-9a41-f8c928889864} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(58)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52592) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(58));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.055414 [ 48602 ] {12bd2f03-8deb-4510-9a41-f8c928889864} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(58)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.452420 [ 48602 ] {01d2780c-d026-42f1-8452-8677da206fb3} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(46)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52724) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(46));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.452703 [ 48602 ] {01d2780c-d026-42f1-8452-8677da206fb3} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(46)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.469402 [ 23573 ] {a735258a-3125-4ca1-a7b4-71a6ce55b57d} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(23)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52738) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(23));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.469726 [ 23573 ] {a735258a-3125-4ca1-a7b4-71a6ce55b57d} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(23)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.474156 [ 48602 ] {245fafdc-2e04-4e47-beca-18205b4450e5} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(22)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52750) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(22));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.474493 [ 48602 ] {245fafdc-2e04-4e47-beca-18205b4450e5} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(22)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.500885 [ 48602 ] {b1272eb7-4d5f-48bd-a49e-2bf3e9c79a4f} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(98)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52756) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(98));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.501257 [ 48602 ] {b1272eb7-4d5f-48bd-a49e-2bf3e9c79a4f} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(98)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.848255 [ 23573 ] {2792c124-7fbd-4abb-ae82-3bf0f836c0df} executeQuery: Code: 42. DB::Exception: Storage ODBC requires exactly 3 parameters: ODBC('DSN', database or schema, table). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:52876) (comment: 01033_storage_odbc_parsing_exception_check.sql) (in query: CREATE TABLE BannerDict (`BannerID` UInt64, `CompaignID` UInt64) ENGINE = ODBC('DSN=pgconn;Database=postgres', bannerdict);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Storages/StorageXDBC.cpp:175: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl(DB::StorageFactory&, String const&)::'lambda'(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003268f7bd 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:31.848480 [ 23573 ] {2792c124-7fbd-4abb-ae82-3bf0f836c0df} TCPHandler: Code: 42. DB::Exception: Storage ODBC requires exactly 3 parameters: ODBC('DSN', database or schema, table). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000001806daea 4. ./build_docker/./src/Storages/StorageXDBC.cpp:175: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl(DB::StorageFactory&, String const&)::'lambda'(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003268f7bd 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:31.873618 [ 5338 ] {0196aed4-089a-4b22-b3f8-0238940d1320} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(41)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52890) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(41));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.873925 [ 5338 ] {0196aed4-089a-4b22-b3f8-0238940d1320} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(41)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.887494 [ 23606 ] {fd01aa0d-ef1f-4625-a5ee-10f2b20ad71a} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(51)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52894) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(51));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.887732 [ 23606 ] {fd01aa0d-ef1f-4625-a5ee-10f2b20ad71a} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(51)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.896399 [ 23573 ] {541c54cd-a57b-48a3-8398-768b7ee5edca} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(64)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52910) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(64));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.896902 [ 23573 ] {541c54cd-a57b-48a3-8398-768b7ee5edca} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(64)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.911830 [ 5338 ] {fa522d75-35dd-43b4-89b8-87f0c93ccde6} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(90)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:52924) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(90));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:31.912100 [ 5338 ] {fa522d75-35dd-43b4-89b8-87f0c93ccde6} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(90)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:32.180426 [ 48599 ] {a3c54002-370c-42dd-ba05-3831c947d489} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of function substring, expected (U)Int*: In scope SELECT substring('hello', []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:52956) (comment: 01033_function_substring.sql) (in query: SELECT substring('hello', []);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionSubstring::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000216aa16b 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:32.180705 [ 48599 ] {a3c54002-370c-42dd-ba05-3831c947d489} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of function substring, expected (U)Int*: In scope SELECT substring('hello', []). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionSubstring::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000216aa16b 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:32.227789 [ 48599 ] {eeb5cf0e-570e-4541-b0e3-6a96f4be64fa} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of function substring, expected (U)Int*: In scope SELECT substring('hello', 1, []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:52956) (comment: 01033_function_substring.sql) (in query: SELECT substring('hello', 1, []);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionSubstring::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000216aa445 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:32.228093 [ 48599 ] {eeb5cf0e-570e-4541-b0e3-6a96f4be64fa} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of function substring, expected (U)Int*: In scope SELECT substring('hello', 1, []). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::(anonymous namespace)::FunctionSubstring::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000216aa445 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000001805d3c2 6. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 7. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 8. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 10. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 11. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 13. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 19. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 24. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 29. ? @ 0x00007fe1df9bbac3 30. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:32.260496 [ 48599 ] {e803e558-7aeb-45dd-9bb9-d4ba2d2e6a1c} executeQuery: Code: 135. DB::Exception: Indices in strings are 1-based. (ZERO_ARRAY_OR_TUPLE_INDEX) (version 24.3.12.76.altinitystable) (from [::1]:52956) (comment: 01033_function_substring.sql) (in query: SELECT substring(materialize('hello'), 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::FunctionSubstring::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000216a9351 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:32.260712 [ 48599 ] {e803e558-7aeb-45dd-9bb9-d4ba2d2e6a1c} TCPHandler: Code: 135. DB::Exception: Indices in strings are 1-based. (ZERO_ARRAY_OR_TUPLE_INDEX), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::(anonymous namespace)::FunctionSubstring::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000216a9351 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 7. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002fb67d46 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::ActionsDAG::updateHeader(DB::Block) const @ 0x000000002fb65d83 12. ./contrib/llvm-project/libcxx/include/unordered_map:1153: DB::ExpressionTransform::transformHeader(DB::Block, DB::ActionsDAG const&) @ 0x0000000033b52db3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, std::shared_ptr const&) @ 0x0000000033eb509c 14. ./build_docker/./src/Planner/Planner.cpp:336: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr const&, String const&, std::vector, std::allocator>>&) @ 0x00000000310190db 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000003101021c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 21. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 26. ? @ 0x00007fe1df9bbac3 27. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:32.315958 [ 5338 ] {8eb5f176-1ecc-4e8b-9a13-71419bc63c99} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(25)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53006) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(25));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:32.316277 [ 5338 ] {8eb5f176-1ecc-4e8b-9a13-71419bc63c99} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(25)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:32.324621 [ 23606 ] {1e712021-bed8-4796-9fda-e7a43a3ff6a6} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(84)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53016) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(84));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:32.325099 [ 23606 ] {1e712021-bed8-4796-9fda-e7a43a3ff6a6} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(84)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:32.325660 [ 22866 ] {557c48d9-8f3d-4edb-897d-79d75d49aa4f} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(77)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53030) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(77));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:32.325934 [ 22866 ] {557c48d9-8f3d-4edb-897d-79d75d49aa4f} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(77)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:32.347809 [ 5338 ] {c90fab5b-2a46-4132-a142-3111ae913ec5} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(41)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53044) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(41));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:32.348105 [ 5338 ] {c90fab5b-2a46-4132-a142-3111ae913ec5} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(41)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:32.723224 [ 22866 ] {65bbdc39-71c1-4f05-80d5-d1c734fe3e83} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(84)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53156) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(84));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:32.723519 [ 22866 ] {65bbdc39-71c1-4f05-80d5-d1c734fe3e83} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(84)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:32.742140 [ 81478 ] {32cda28f-4eae-4ddd-bb6c-7f690f1b66a5} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(79)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53172) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(79));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:32.742542 [ 81478 ] {32cda28f-4eae-4ddd-bb6c-7f690f1b66a5} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(79)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:32.785945 [ 22866 ] {aac382e3-362f-41ff-965a-670b3dd28154} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(33)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53220) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(33));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:32.786230 [ 22866 ] {aac382e3-362f-41ff-965a-670b3dd28154} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(33)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:32.800564 [ 23553 ] {8b56b315-47e0-4445-b12b-65feca042f35} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(58)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53222) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(58));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:32.800864 [ 23553 ] {8b56b315-47e0-4445-b12b-65feca042f35} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:32. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(58)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:32.853611 [ 81478 ] {ae54b412-6e56-47a6-a79c-0a552c1a1e66} ReadWriteBufferFromHTTP: Failed to make request to '' redirect to '/'. Error: 'DB::Exception: Unsupported scheme in URI '/''. Failed at try 1/10. 2025.03.05 21:16:32.882387 [ 81478 ] {ae54b412-6e56-47a6-a79c-0a552c1a1e66} executeQuery: Code: 422. DB::Exception: Unsupported scheme in URI '/': The data format cannot be detected by the contents of the files. You can specify the format manually. (UNSUPPORTED_URI_SCHEME) (version 24.3.12.76.altinitystable) (from [::1]:53232) (comment: 01030_storage_url_syntax.sql) (in query: create table test_table_url_syntax (id UInt32) ENGINE = URL('') ;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::HTTPConnectionPools::Impl::useSecureConnection(Poco::URI const&, DB::ProxyConfiguration const&) @ 0x00000000249b721c 5. ./build_docker/./src/Common/HTTPConnectionPool.cpp:866: DB::HTTPConnectionPools::Impl::getPoolImpl(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x00000000249b3b97 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:782: DB::HTTPConnectionPools::Impl::getPool(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x00000000249b30a8 7. ./build_docker/./src/IO/HTTPCommon.cpp:52: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration) @ 0x0000000024ab51cf 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:246: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000290691b5 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 16. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 17. ./src/IO/ReadWriteBufferFromHTTP.h:242: DB::StorageURLSource::getFirstAvailableURIAndReadBuffer(std::__wrap_iter&, std::__wrap_iter const&, std::shared_ptr, std::vector, std::allocator>> const&, String const&, std::function>&)>, DB::ConnectionTimeouts const&, Poco::Net::HTTPBasicCredentials&, std::vector> const&, bool, bool) @ 0x000000003265acbf 18. ./build_docker/./src/Storages/StorageURL.cpp:783: DB::(anonymous namespace)::ReadBufferIterator::next() @ 0x000000003266bd6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033512ef7 20. ./contrib/llvm-project/libcxx/include/optional:260: DB::detectFormatAndReadSchema(std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033519a0e 21. ./build_docker/./src/Storages/StorageURL.cpp:946: DB::IStorageURLBase::getTableStructureAndFormatFromDataImpl(std::optional, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x000000003265e3fe 22. ./contrib/llvm-project/libcxx/include/optional:260: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000032656d3e 23. ./build_docker/./src/Storages/StorageURL.cpp:1363: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000032666400 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageURL* std::construct_at[abi:v15000], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000003267e765 25. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], String&, std::vector>&, String&, std::shared_ptr&>(std::allocator, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000003267e48e 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, void>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000003267e1bb 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000032674f53 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 29. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 30. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 31. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 2025.03.05 21:16:32.882656 [ 81478 ] {ae54b412-6e56-47a6-a79c-0a552c1a1e66} TCPHandler: Code: 422. DB::Exception: Unsupported scheme in URI '/': The data format cannot be detected by the contents of the files. You can specify the format manually. (UNSUPPORTED_URI_SCHEME), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::HTTPConnectionPools::Impl::useSecureConnection(Poco::URI const&, DB::ProxyConfiguration const&) @ 0x00000000249b721c 5. ./build_docker/./src/Common/HTTPConnectionPool.cpp:866: DB::HTTPConnectionPools::Impl::getPoolImpl(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x00000000249b3b97 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:782: DB::HTTPConnectionPools::Impl::getPool(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x00000000249b30a8 7. ./build_docker/./src/IO/HTTPCommon.cpp:52: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration) @ 0x0000000024ab51cf 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:246: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000290691b5 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000029069958 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000002906aa17 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:448: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002906fcfe 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002906542b 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002906d3dc 14. DB::ReadBuffer::next() @ 0x0000000018778250 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000029068681 16. ./contrib/llvm-project/libcxx/include/vector:580: std::__unique_if::__unique_single std::make_unique[abi:v15000]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x000000002905c495 17. ./src/IO/ReadWriteBufferFromHTTP.h:242: DB::StorageURLSource::getFirstAvailableURIAndReadBuffer(std::__wrap_iter&, std::__wrap_iter const&, std::shared_ptr, std::vector, std::allocator>> const&, String const&, std::function>&)>, DB::ConnectionTimeouts const&, Poco::Net::HTTPBasicCredentials&, std::vector> const&, bool, bool) @ 0x000000003265acbf 18. ./build_docker/./src/Storages/StorageURL.cpp:783: DB::(anonymous namespace)::ReadBufferIterator::next() @ 0x000000003266bd6e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033512ef7 20. ./contrib/llvm-project/libcxx/include/optional:260: DB::detectFormatAndReadSchema(std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x0000000033519a0e 21. ./build_docker/./src/Storages/StorageURL.cpp:946: DB::IStorageURLBase::getTableStructureAndFormatFromDataImpl(std::optional, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x000000003265e3fe 22. ./contrib/llvm-project/libcxx/include/optional:260: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000032656d3e 23. ./build_docker/./src/Storages/StorageURL.cpp:1363: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000032666400 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageURL* std::construct_at[abi:v15000], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000003267e765 25. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], String&, std::vector>&, String&, std::shared_ptr&>(std::allocator, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000003267e48e 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, void>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000003267e1bb 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000032674f53 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 29. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 30. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 31. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 2025.03.05 21:16:32.901568 [ 81478 ] {45af33b1-ed5b-4196-8c57-849ab81a8b40} executeQuery: Code: 42. DB::Exception: Storage URL requires 1-4 arguments: url, name of used format (taken from file extension by default), optional compression method, optional headers (specified as `headers('name'='value', 'name2'='value2')`). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:53232) (comment: 01030_storage_url_syntax.sql) (in query: create table test_table_url_syntax (id UInt32) ENGINE = URL('','','','') ;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageURL.cpp:1523: DB::StorageURL::getConfiguration(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000003266b27d 5. ./build_docker/./src/Storages/StorageURL.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000032674ca8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:32.901784 [ 81478 ] {45af33b1-ed5b-4196-8c57-849ab81a8b40} TCPHandler: Code: 42. DB::Exception: Storage URL requires 1-4 arguments: url, name of used format (taken from file extension by default), optional compression method, optional headers (specified as `headers('name'='value', 'name2'='value2')`). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/StorageURL.cpp:1523: DB::StorageURL::getConfiguration(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000003266b27d 5. ./build_docker/./src/Storages/StorageURL.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000032674ca8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:32.950787 [ 23573 ] {c959e587-82cd-488b-bbec-c160d18d9cf5} executeQuery: Code: 43. DB::Exception: Types Array(String) and Float64 are non-conforming as arguments for aggregate function avgWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.3.12.76.altinitystable) (from [::1]:53236) (comment: 01035_avg_weighted_long.sh) (in query: SELECT avgWeighted(['string'], toFloat64(0))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002507d3e3 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAvgWeighted.cpp:0: DB::(anonymous namespace)::createAggregateFunctionAvgWeighted(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000024bcba6b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:32.951228 [ 23573 ] {c959e587-82cd-488b-bbec-c160d18d9cf5} TCPHandler: Code: 43. DB::Exception: Types Array(String) and Float64 are non-conforming as arguments for aggregate function avgWeighted. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000002507d3e3 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAvgWeighted.cpp:0: DB::(anonymous namespace)::createAggregateFunctionAvgWeighted(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000024bcba6b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002e8d8014 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:123: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002e8d6038 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b25b9 8. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 11. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 12. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 17. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:33.138261 [ 5913 ] {} ExternalDictionaries: Could not update cache dictionary 'one_cell_cache_ints', next update is scheduled at 2025-03-05 21:16:38: Code: 81. DB::Exception: Database test_01054 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a6bd 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x00000000308a1073 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089c809 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6962: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086fd78 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:171: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000029011cf3 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000002901238a 20. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029501ec9 21. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:33.138931 [ 22866 ] {f530a81a-2527-4641-bfe8-52c2688d2bfe} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a6bd 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x00000000308a1073 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089c809 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6962: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086fd78 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:171: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000029011cf3 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000002901238a 20. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029501ec9 21. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(8)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53342) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(8));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:33.139226 [ 22866 ] {f530a81a-2527-4641-bfe8-52c2688d2bfe} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002fd8a6bd 5. ./build_docker/./src/Interpreters/Context.cpp:4771: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002fc88bb6 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x00000000308a1073 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::tryResolveIdentifier(DB::(anonymous namespace)::IdentifierLookup const&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::IdentifierResolveSettings) @ 0x000000003089c809 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6962: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086fd78 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:171: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x0000000029011cf3 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000002901238a 20. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029501ec9 21. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(8)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:33.171916 [ 22866 ] {a19b101c-b7f7-47d2-a675-3e04b73a7d93} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(26)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53346) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(26));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:33.172342 [ 22866 ] {a19b101c-b7f7-47d2-a675-3e04b73a7d93} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(26)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:33.233073 [ 22866 ] {a4227dd3-75e1-4747-b0e3-41989acb52f3} executeQuery: Code: 36. DB::Exception: Bad hdfs url: . It should have structure 'hdfs://:/'. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:53368) (comment: 01030_storage_hdfs_syntax.sql) (in query: create table test_table_hdfs_syntax (id UInt32) ENGINE = HDFS('') ;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageHDFS* std::construct_at[abi:v15000], String&, bool, std::shared_ptr&, DB::StorageHDFS*>(DB::StorageHDFS*, String&, DB::StorageID const&, String&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, bool&&, std::shared_ptr&) @ 0x000000002ebd273d 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], String&, bool, std::shared_ptr&>(std::allocator, String&, DB::StorageID const&, String&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, bool&&, std::shared_ptr&) @ 0x000000002ebd2465 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, DB::StorageID const&, String&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, bool, std::shared_ptr&, void>(std::allocator const&, String&, DB::StorageID const&, String&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, bool&&, std::shared_ptr&) @ 0x000000002ebd21b5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002ebc2a8f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:33.233269 [ 22866 ] {a4227dd3-75e1-4747-b0e3-41989acb52f3} TCPHandler: Code: 36. DB::Exception: Bad hdfs url: . It should have structure 'hdfs://:/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/HDFS/HDFSCommon.cpp:196: DB::checkHDFSURL(String const&) @ 0x000000002ebd58d2 5. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:0: DB::StorageHDFS::StorageHDFS(String const&, DB::StorageID const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, bool, std::shared_ptr) @ 0x000000002ebad0ed 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageHDFS* std::construct_at[abi:v15000], String&, bool, std::shared_ptr&, DB::StorageHDFS*>(DB::StorageHDFS*, String&, DB::StorageID const&, String&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, bool&&, std::shared_ptr&) @ 0x000000002ebd273d 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], String&, bool, std::shared_ptr&>(std::allocator, String&, DB::StorageID const&, String&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, bool&&, std::shared_ptr&) @ 0x000000002ebd2465 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String&, DB::StorageID const&, String&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, bool, std::shared_ptr&, void>(std::allocator const&, String&, DB::StorageID const&, String&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, bool&&, std::shared_ptr&) @ 0x000000002ebd21b5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002ebc2a8f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:33.233557 [ 22858 ] {ad8f6c18-e0fb-4d45-9deb-84cc5fada60b} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(41)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53382) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(41));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:33.233729 [ 23553 ] {26521725-9b10-4c8b-9ed8-044ad1920b4c} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(60)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53380) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(60));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:33.233811 [ 22858 ] {ad8f6c18-e0fb-4d45-9deb-84cc5fada60b} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(41)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:33.234102 [ 23553 ] {26521725-9b10-4c8b-9ed8-044ad1920b4c} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(60)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:33.253093 [ 22866 ] {68d049ff-595e-47eb-ba69-068d80d592b3} executeQuery: Code: 42. DB::Exception: Storage HDFS requires 1, 2 or 3 arguments: url, name of used format (taken from file extension by default) and optional compression method. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.3.12.76.altinitystable) (from [::1]:53368) (comment: 01030_storage_hdfs_syntax.sql) (in query: create table test_table_hdfs_syntax (id UInt32) ENGINE = HDFS('','','', '') ;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:1144: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002ebc2caf 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:33.253248 [ 22866 ] {68d049ff-595e-47eb-ba69-068d80d592b3} TCPHandler: Code: 42. DB::Exception: Storage HDFS requires 1, 2 or 3 arguments: url, name of used format (taken from file extension by default) and optional compression method. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Storages/HDFS/StorageHDFS.cpp:1144: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002ebc2caf 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:33.536763 [ 22858 ] {6c328419-890e-4306-ae3a-2bd75db899f4} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(77)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53498) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(77));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:33.537134 [ 22858 ] {6c328419-890e-4306-ae3a-2bd75db899f4} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(77)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:33.600418 [ 23553 ] {f4328ab6-fc7b-4a5e-8072-158d1570691b} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(12)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53512) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(12));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:33.600803 [ 23553 ] {f4328ab6-fc7b-4a5e-8072-158d1570691b} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(12)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:33.645621 [ 22858 ] {f7c7768c-d2fe-42f2-95fa-00d04394bca7} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(94)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53526) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(94));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:33.646036 [ 22858 ] {f7c7768c-d2fe-42f2-95fa-00d04394bca7} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(94)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:33.670240 [ 23601 ] {59a8cf45-948d-4846-93b2-b08f72f468b0} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(27)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53538) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(27));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:33.670599 [ 23601 ] {59a8cf45-948d-4846-93b2-b08f72f468b0} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(27)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:33.924770 [ 22858 ] {c685ade2-26ad-4e19-acc9-97dd39398231} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 12.77 MiB (attempt to allocate chunk of 8388608 bytes), maximum: 9.54 MiB. (MEMORY_LIMIT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:53606) (comment: 01019_Buffer_and_max_memory_usage.sql) (in query: INSERT INTO buffer_ SELECT toUInt64(number) FROM system.numbers LIMIT toUInt64(10e6+1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000002461ef1f 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000018062b29 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000018062951 10. ./build_docker/./src/Columns/ColumnVector.cpp:497: DB::ColumnVector::insertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000031d9c913 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:140: void DB::SquashingTransform::append(DB::Block&&) @ 0x0000000032ec4ae5 12. ./build_docker/./src/Interpreters/SquashingTransform.cpp:70: DB::Block DB::SquashingTransform::addImpl(DB::Block&&) @ 0x0000000032ec4410 13. ./build_docker/./src/Interpreters/SquashingTransform.cpp:20: DB::SquashingTransform::add(DB::Block&&) @ 0x0000000032ec3e6e 14. ./src/Core/Block.h:25: DB::SimpleSquashingChunksTransform::transform(DB::Chunk&) @ 0x0000000033c46fe2 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 21. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 22. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:33.924958 [ 22858 ] {c685ade2-26ad-4e19-acc9-97dd39398231} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 12.77 MiB (attempt to allocate chunk of 8388608 bytes), maximum: 9.54 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x00000000246a05ac 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469f494 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000002469edf5 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000002462089d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000002461ef1f 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000018062b29 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000018062951 10. ./build_docker/./src/Columns/ColumnVector.cpp:497: DB::ColumnVector::insertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000031d9c913 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:140: void DB::SquashingTransform::append(DB::Block&&) @ 0x0000000032ec4ae5 12. ./build_docker/./src/Interpreters/SquashingTransform.cpp:70: DB::Block DB::SquashingTransform::addImpl(DB::Block&&) @ 0x0000000032ec4410 13. ./build_docker/./src/Interpreters/SquashingTransform.cpp:20: DB::SquashingTransform::add(DB::Block&&) @ 0x0000000032ec3e6e 14. ./src/Core/Block.h:25: DB::SimpleSquashingChunksTransform::transform(DB::Chunk&) @ 0x0000000033c46fe2 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000028fe9d0b 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003353b4cd 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000033558c97 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000335588aa 21. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000033557423 22. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:34.007204 [ 23553 ] {5447615e-d8e2-471a-a8e3-f63be189f637} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(48)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53634) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(48));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.007708 [ 23553 ] {5447615e-d8e2-471a-a8e3-f63be189f637} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(48)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.059431 [ 23553 ] {4f46adfd-3159-443c-a543-c34818744c6b} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(76)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53642) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(76));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.059817 [ 23553 ] {4f46adfd-3159-443c-a543-c34818744c6b} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(76)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.094947 [ 23553 ] {ed12e668-bb9b-452c-a4ff-65426bbe3278} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(41)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53660) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(41));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.095345 [ 23553 ] {ed12e668-bb9b-452c-a4ff-65426bbe3278} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(41)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.127233 [ 23553 ] {d7a7fa35-c3f4-49b7-8714-a000d2a5d034} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(78)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53662) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(78));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.127552 [ 23553 ] {d7a7fa35-c3f4-49b7-8714-a000d2a5d034} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(78)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.290197 [ 22858 ] {0675af30-9a32-43f6-a87c-f8fd697422f3} StorageBuffer (test_04270kzo.buffer_): Destination table test_04270kzo.null_ doesn't exist. Block of data is discarded. 2025.03.05 21:16:34.459449 [ 22865 ] {9286f746-9d70-453e-af77-15bd0754daf7} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(43)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53706) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(43));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.459763 [ 22865 ] {9286f746-9d70-453e-af77-15bd0754daf7} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(43)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.467885 [ 23587 ] {57365530-d1aa-46da-b244-c2636dfe062e} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(65)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53716) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(65));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.468251 [ 23587 ] {57365530-d1aa-46da-b244-c2636dfe062e} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(65)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.527347 [ 22865 ] {bf3a0ed9-94d4-4ff2-9153-f57eed58243a} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(71)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53730) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(71));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.527627 [ 22865 ] {bf3a0ed9-94d4-4ff2-9153-f57eed58243a} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(71)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.576036 [ 22865 ] {e551d2d3-a020-4168-9077-b3239a94c3d5} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(97)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53734) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(97));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.576358 [ 22865 ] {e551d2d3-a020-4168-9077-b3239a94c3d5} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(97)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.890486 [ 48631 ] {a3d7a5ee-0912-4bf9-be5b-20bdf1d8e8e2} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(95)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53802) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(95));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.890760 [ 48631 ] {a3d7a5ee-0912-4bf9-be5b-20bdf1d8e8e2} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(95)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.909506 [ 12524 ] {17f33671-bbee-4d2b-b028-75b9d382fb3d} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(21)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53818) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(21));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.909797 [ 12524 ] {17f33671-bbee-4d2b-b028-75b9d382fb3d} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(21)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.958883 [ 22865 ] {3f00851f-d67c-458c-b1b5-6e427e18e448} executeQuery: Code: 36. DB::Exception: No such attribute 'prefixprefixprefixprefix': In scope SELECT '127.0.0.0/24' = dictGetString(concat('test_pyanb1q5', '.dict_ipv4_trie'), 'prefixprefixprefixprefix', tuple(IPv4StringToNumOrDefault('127.0.0.0127.0.0.0'))). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:53794) (comment: 01018_ip_dictionary_long.sql) (in query: SELECT '127.0.0.0/24' = dictGetString(concat('test_pyanb1q5', '.dict_ipv4_trie'), 'prefixprefixprefixprefix', tuple(IPv4StringToNumOrDefault('127.0.0.0127.0.0.0')))), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:184: DB::DictionaryStructure::getAttribute(String const&) const @ 0x000000002e83c49c 5. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000188124d8 6. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001884851f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:16:34.959145 [ 22865 ] {3f00851f-d67c-458c-b1b5-6e427e18e448} TCPHandler: Code: 36. DB::Exception: No such attribute 'prefixprefixprefixprefix': In scope SELECT '127.0.0.0/24' = dictGetString(concat('test_pyanb1q5', '.dict_ipv4_trie'), 'prefixprefixprefixprefix', tuple(IPv4StringToNumOrDefault('127.0.0.0127.0.0.0'))). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:184: DB::DictionaryStructure::getAttribute(String const&) const @ 0x000000002e83c49c 5. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000188124d8 6. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001884851f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308a719d 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:16:34.959436 [ 23587 ] {f451d4e2-5708-442e-b07a-9d3dd7c48f7f} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(38)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53822) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(38));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:34.959804 [ 23587 ] {f451d4e2-5708-442e-b07a-9d3dd7c48f7f} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(38)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:35.008049 [ 23587 ] {164895a5-1cff-4b9f-bfb9-9ee30ebe22b2} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(93)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53824) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(93));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:35.008404 [ 23587 ] {164895a5-1cff-4b9f-bfb9-9ee30ebe22b2} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(93)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:35.315793 [ 23587 ] {fd6d14fa-f5ef-4f05-838f-b18af99ef32d} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(63)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53912) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(63));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:35.316060 [ 23587 ] {fd6d14fa-f5ef-4f05-838f-b18af99ef32d} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(63)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:35.357333 [ 23587 ] {7a1270c6-a471-45ba-97b7-39a96a245876} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(88)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53948) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(88));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:35.360166 [ 23587 ] {7a1270c6-a471-45ba-97b7-39a96a245876} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(88)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:35.376552 [ 48631 ] {61f7d5be-b5c6-499d-a9ad-24be07717c54} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(79)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53952) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(79));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:35.376929 [ 48631 ] {61f7d5be-b5c6-499d-a9ad-24be07717c54} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(79)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:35.447016 [ 12524 ] {eb4cc495-a93f-4f60-aadb-e315a027228d} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(40)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:53972) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(40));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:35.447335 [ 12524 ] {eb4cc495-a93f-4f60-aadb-e315a027228d} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(40)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:36.455732 [ 5338 ] {ab38f6cf-783e-425a-a0d0-88c53a2ac8e9} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(62)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:54466) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(62));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:36.456004 [ 5338 ] {ab38f6cf-783e-425a-a0d0-88c53a2ac8e9} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(62)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:36.518895 [ 14973 ] {b932ed51-9958-4028-866a-5e1e62532e8a} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(25)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:54534) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(25));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:36.519181 [ 14973 ] {b932ed51-9958-4028-866a-5e1e62532e8a} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(25)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:36.520264 [ 48603 ] {1bc926ba-fc92-429a-8d43-f276404cb0a0} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(74)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:54520) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(74));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:36.520572 [ 48603 ] {1bc926ba-fc92-429a-8d43-f276404cb0a0} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(74)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:36.728689 [ 48603 ] {7b7b30ed-5b38-478e-9603-496e4d91402f} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(89)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:54576) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(89));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:36.729027 [ 48603 ] {7b7b30ed-5b38-478e-9603-496e4d91402f} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(89)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:36.966160 [ 48603 ] {177ea268-a2e7-4916-8a3f-90f50af9556a} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(95)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:54724) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(95));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:36.966553 [ 48603 ] {177ea268-a2e7-4916-8a3f-90f50af9556a} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(95)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:36.972191 [ 48581 ] {bd8f86c3-f9d1-474c-9262-1828b5147636} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(39)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:54732) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(39));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:36.972516 [ 48581 ] {bd8f86c3-f9d1-474c-9262-1828b5147636} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(39)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:36.989716 [ 5338 ] {513a3833-1f38-42a3-b690-2565c7aad0cf} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(39)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:54748) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(39));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:36.990080 [ 5338 ] {513a3833-1f38-42a3-b690-2565c7aad0cf} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(39)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:37.016395 [ 81473 ] {22} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:54646) (comment: 01019_parallel_parsing_cancel.sh) (in query: INSERT INTO data_b_01019 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:37.016802 [ 81473 ] {22} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:37.035564 [ 81473 ] {} TCPHandler: Code: 101. DB::NetException: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, char const (&) [44]) @ 0x00000000334c7456 4. ./build_docker/./src/Server/TCPHandler.cpp:2028: DB::TCPHandler::receiveUnexpectedData(bool) @ 0x00000000334bd3a1 5. ./build_docker/./src/Server/TCPHandler.cpp:1623: DB::TCPHandler::receivePacket() @ 0x000000003349bf98 6. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:37.038323 [ 14973 ] {11} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:54658) (comment: 01019_parallel_parsing_cancel.sh) (in query: INSERT INTO data_a_01019 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:37.038725 [ 14973 ] {11} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:37.039262 [ 14973 ] {} TCPHandler: Code: 101. DB::NetException: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, char const (&) [44]) @ 0x00000000334c7456 4. ./build_docker/./src/Server/TCPHandler.cpp:2028: DB::TCPHandler::receiveUnexpectedData(bool) @ 0x00000000334bd3a1 5. ./build_docker/./src/Server/TCPHandler.cpp:1623: DB::TCPHandler::receivePacket() @ 0x000000003349bf98 6. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:37.166389 [ 81473 ] {cb7cb713-4fdc-4c2c-9312-4c36777ee7d1} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(15)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:54792) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(15));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:37.167069 [ 81473 ] {cb7cb713-4fdc-4c2c-9312-4c36777ee7d1} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(15)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:37.413159 [ 14973 ] {4264d6c9-d008-4c73-9003-7ce367216e2c} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(47)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:54870) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(47));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:37.413693 [ 14973 ] {4264d6c9-d008-4c73-9003-7ce367216e2c} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(47)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:37.425888 [ 23586 ] {704be7de-12e1-44a4-bede-087a33e6f550} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(68)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:54890) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(68));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:37.426355 [ 730 ] {1d6c86db-c6d9-4d67-bce7-2afd3b191508} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(98)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.3.12.76.altinitystable) (from [::1]:54884) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(98));), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:37.426405 [ 23586 ] {704be7de-12e1-44a4-bede-087a33e6f550} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(68)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:37.426695 [ 730 ] {1d6c86db-c6d9-4d67-bce7-2afd3b191508} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-03-05 21:16:38. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000001805f1aa 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x0000000029505256 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>)::operator()(std::shared_ptr>) const @ 0x0000000029516903 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::function>)>::operator()(std::shared_ptr>) const @ 0x000000002951c251 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000002951bee4 8. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 9. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 10. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(98)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000190f1eca 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000002951bcd9 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294fc0ca 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000294faf78 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000188149e5 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018810831 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 11. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 13. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 15. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 17. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 18. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 20. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 21. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 26. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 28. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 31. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 2025.03.05 21:16:37.698489 [ 48603 ] {22} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:54914) (comment: 01019_parallel_parsing_cancel.sh) (in query: INSERT INTO data_b_01019 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:37.698708 [ 48603 ] {22} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:37.698962 [ 48603 ] {} TCPHandler: Code: 101. DB::NetException: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, char const (&) [44]) @ 0x00000000334c7456 4. ./build_docker/./src/Server/TCPHandler.cpp:2028: DB::TCPHandler::receiveUnexpectedData(bool) @ 0x00000000334bd3a1 5. ./build_docker/./src/Server/TCPHandler.cpp:1623: DB::TCPHandler::receivePacket() @ 0x000000003349bf98 6. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:37.708544 [ 730 ] {11} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:54928) (comment: 01019_parallel_parsing_cancel.sh) (in query: INSERT INTO data_a_01019 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:37.708727 [ 730 ] {11} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:37.708892 [ 730 ] {} TCPHandler: Code: 101. DB::NetException: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, char const (&) [44]) @ 0x00000000334c7456 4. ./build_docker/./src/Server/TCPHandler.cpp:2028: DB::TCPHandler::receiveUnexpectedData(bool) @ 0x00000000334bd3a1 5. ./build_docker/./src/Server/TCPHandler.cpp:1623: DB::TCPHandler::receivePacket() @ 0x000000003349bf98 6. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:38.326154 [ 730 ] {22} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:55018) (comment: 01019_parallel_parsing_cancel.sh) (in query: INSERT INTO data_b_01019 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:38.326421 [ 730 ] {22} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:38.326684 [ 730 ] {} TCPHandler: Code: 101. DB::NetException: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, char const (&) [44]) @ 0x00000000334c7456 4. ./build_docker/./src/Server/TCPHandler.cpp:2028: DB::TCPHandler::receiveUnexpectedData(bool) @ 0x00000000334bd3a1 5. ./build_docker/./src/Server/TCPHandler.cpp:1623: DB::TCPHandler::receivePacket() @ 0x000000003349bf98 6. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:38.406211 [ 48603 ] {7ffdb578-898c-47d5-98cd-2025a193ca7d} executeQuery: Code: 69. DB::Exception: Second argument (shingle size) of function wordShingleSimHash cannot be greater then 25: In scope SELECT wordShingleSimHash('foobar', 9223372036854775807). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:55008) (comment: 01016_simhash_minhash.sql) (in query: SELECT wordShingleSimHash('foobar', 9223372036854775807);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x0000000018bc1813 4. DB::FunctionsStringHash, DB::NameWordShingleSimHash, true, false>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001931dc24 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:38.406415 [ 48603 ] {7ffdb578-898c-47d5-98cd-2025a193ca7d} TCPHandler: Code: 69. DB::Exception: Second argument (shingle size) of function wordShingleSimHash cannot be greater then 25: In scope SELECT wordShingleSimHash('foobar', 9223372036854775807). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x0000000018bc1813 4. DB::FunctionsStringHash, DB::NameWordShingleSimHash, true, false>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001931dc24 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:38.408319 [ 48603 ] {3a8a865f-7a06-49ff-bf1e-210afbca9e63} executeQuery: Code: 69. DB::Exception: Second argument (shingle size) of function wordShingleSimHash cannot be greater then 25: In scope SELECT wordShingleSimHash('foobar', 1001). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:55008) (comment: 01016_simhash_minhash.sql) (in query: SELECT wordShingleSimHash('foobar', 1001);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x0000000018bc1813 4. DB::FunctionsStringHash, DB::NameWordShingleSimHash, true, false>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001931dc24 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:38.408427 [ 48603 ] {3a8a865f-7a06-49ff-bf1e-210afbca9e63} TCPHandler: Code: 69. DB::Exception: Second argument (shingle size) of function wordShingleSimHash cannot be greater then 25: In scope SELECT wordShingleSimHash('foobar', 1001). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x0000000018bc1813 4. DB::FunctionsStringHash, DB::NameWordShingleSimHash, true, false>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001931dc24 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:38.431903 [ 48603 ] {d57692d6-4535-4845-86f5-364a2f87d9b7} executeQuery: Code: 69. DB::Exception: Second argument (shingle size) of function wordShingleSimHash cannot be zero: In scope SELECT wordShingleSimHash('foobar', 0). (ARGUMENT_OUT_OF_BOUND) (version 24.3.12.76.altinitystable) (from [::1]:55008) (comment: 01016_simhash_minhash.sql) (in query: SELECT wordShingleSimHash('foobar', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionsStringHash, DB::NameWordShingleSimHash, true, false>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001931db38 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:38.432080 [ 48603 ] {d57692d6-4535-4845-86f5-364a2f87d9b7} TCPHandler: Code: 69. DB::Exception: Second argument (shingle size) of function wordShingleSimHash cannot be zero: In scope SELECT wordShingleSimHash('foobar', 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::FunctionsStringHash, DB::NameWordShingleSimHash, true, false>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001931db38 5. ./build_docker/./src/Functions/IFunction.cpp:522: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002e844713 6. ./build_docker/./src/Functions/IFunction.cpp:468: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002e843f66 7. ./build_docker/./src/Functions/IFunction.cpp:483: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002e844916 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b1ed7 9. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 10. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 12. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 13. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 23. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:38.775718 [ 48603 ] {11} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:55116) (comment: 01019_parallel_parsing_cancel.sh) (in query: INSERT INTO data_a_01019 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:38.775907 [ 48603 ] {11} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:38.776103 [ 48603 ] {} TCPHandler: Code: 101. DB::NetException: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, char const (&) [44]) @ 0x00000000334c7456 4. ./build_docker/./src/Server/TCPHandler.cpp:2028: DB::TCPHandler::receiveUnexpectedData(bool) @ 0x00000000334bd3a1 5. ./build_docker/./src/Server/TCPHandler.cpp:1623: DB::TCPHandler::receivePacket() @ 0x000000003349bf98 6. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:38.938491 [ 5338 ] {22} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:55130) (comment: 01019_parallel_parsing_cancel.sh) (in query: INSERT INTO data_b_01019 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:38.938672 [ 5338 ] {22} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:38.938847 [ 5338 ] {} TCPHandler: Code: 101. DB::NetException: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, char const (&) [44]) @ 0x00000000334c7456 4. ./build_docker/./src/Server/TCPHandler.cpp:2028: DB::TCPHandler::receiveUnexpectedData(bool) @ 0x00000000334bd3a1 5. ./build_docker/./src/Server/TCPHandler.cpp:1623: DB::TCPHandler::receivePacket() @ 0x000000003349bf98 6. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.532143 [ 23586 ] {22} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:42672) (comment: 01019_parallel_parsing_cancel.sh) (in query: INSERT INTO data_b_01019 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.532346 [ 23586 ] {22} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.532592 [ 23586 ] {} TCPHandler: Code: 101. DB::NetException: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, char const (&) [44]) @ 0x00000000334c7456 4. ./build_docker/./src/Server/TCPHandler.cpp:2028: DB::TCPHandler::receiveUnexpectedData(bool) @ 0x00000000334bd3a1 5. ./build_docker/./src/Server/TCPHandler.cpp:1623: DB::TCPHandler::receivePacket() @ 0x000000003349bf98 6. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.642274 [ 48599 ] {91ab641a-c2b4-47ee-9b23-5ba2ad083f53} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42718) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 CROSS JOIN t1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109afc1 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.642419 [ 48599 ] {91ab641a-c2b4-47ee-9b23-5ba2ad083f53} TCPHandler: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109afc1 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.652404 [ 48599 ] {b23ebb30-c8f1-4f95-bd36-f1ddf00039ad} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42718) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ANY RIGHT JOIN t1 ON t1.x = t0.x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.652558 [ 48599 ] {b23ebb30-c8f1-4f95-bd36-f1ddf00039ad} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.681844 [ 48599 ] {e8cbc56e-9737-40ac-8196-bc7228b94d50} executeQuery: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42718) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ANY FULL JOIN t1 ON t1.x = t0.x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:915: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030824bbd 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.682119 [ 48599 ] {e8cbc56e-9737-40ac-8196-bc7228b94d50} TCPHandler: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:915: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030824bbd 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.692535 [ 48599 ] {073d0154-611a-4c8b-8d5a-ef60825ceb65} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42718) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ANY RIGHT JOIN t1 USING (x);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.692731 [ 48599 ] {073d0154-611a-4c8b-8d5a-ef60825ceb65} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.694602 [ 48599 ] {241cb084-0b93-4845-8e78-fef43e2f7f7b} executeQuery: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42718) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ANY FULL JOIN t1 USING (x);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:915: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030824bbd 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.694771 [ 48599 ] {241cb084-0b93-4845-8e78-fef43e2f7f7b} TCPHandler: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:915: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000030824bbd 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:286: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030819830 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811d53 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000030811823 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000030811122 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030ffe563 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 12. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 17. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 22. ? @ 0x00007fe1df9bbac3 23. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.704546 [ 48599 ] {b36d020b-585b-458c-a7c1-4a688a8a5d0f} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42718) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 SEMI RIGHT JOIN t1 ON t1.x = t0.x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.704794 [ 48599 ] {b36d020b-585b-458c-a7c1-4a688a8a5d0f} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.711122 [ 48599 ] {19b68a02-0d0c-4da9-88f3-b9954d73f1d4} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42718) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 SEMI RIGHT JOIN t1 USING (x);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.711290 [ 48599 ] {19b68a02-0d0c-4da9-88f3-b9954d73f1d4} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.716563 [ 48599 ] {96d04f17-21f1-4823-8e5a-2c2f6c73326a} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42718) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ANTI LEFT JOIN t1 ON t1.x = t0.x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.716694 [ 48599 ] {96d04f17-21f1-4823-8e5a-2c2f6c73326a} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.718585 [ 48599 ] {4e0e4c9b-eb57-4408-afa8-f3effa62d4e2} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42718) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ANTI RIGHT JOIN t1 ON t1.x = t0.x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.718684 [ 48599 ] {4e0e4c9b-eb57-4408-afa8-f3effa62d4e2} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.720534 [ 48599 ] {bd31217d-f6d7-4ebd-8e17-6eccc06e8c2d} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42718) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ANTI LEFT JOIN t1 USING (x);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.720637 [ 48599 ] {bd31217d-f6d7-4ebd-8e17-6eccc06e8c2d} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.722559 [ 48599 ] {bf54f790-cb2c-4250-8d41-a1de31db6aad} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42718) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ANTI RIGHT JOIN t1 USING (x);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.722661 [ 48599 ] {bf54f790-cb2c-4250-8d41-a1de31db6aad} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.727275 [ 48599 ] {c6c6d22a-a52b-4fa1-be58-597369f53f9a} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42718) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ASOF LEFT JOIN t1 ON t1.x = t0.x AND t0.y > t1.y;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.727430 [ 48599 ] {c6c6d22a-a52b-4fa1-be58-597369f53f9a} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.729545 [ 48599 ] {486c5a4d-5d71-4b39-a664-954e01199e62} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.3.12.76.altinitystable) (from [::1]:42718) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ASOF LEFT JOIN t1 USING (x, y);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.729653 [ 48599 ] {486c5a4d-5d71-4b39-a664-954e01199e62} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x000000003109a8dd 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1361: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003106ca9a 6. ./contrib/llvm-project/libcxx/include/vector:1562: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104f096 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.825951 [ 23586 ] {11} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:42746) (comment: 01019_parallel_parsing_cancel.sh) (in query: INSERT INTO data_a_01019 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.826124 [ 23586 ] {11} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:39.826329 [ 23586 ] {} TCPHandler: Code: 101. DB::NetException: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, char const (&) [44]) @ 0x00000000334c7456 4. ./build_docker/./src/Server/TCPHandler.cpp:2028: DB::TCPHandler::receiveUnexpectedData(bool) @ 0x00000000334bd3a1 5. ./build_docker/./src/Server/TCPHandler.cpp:1623: DB::TCPHandler::receivePacket() @ 0x000000003349bf98 6. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:40.263955 [ 48599 ] {22} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:42842) (comment: 01019_parallel_parsing_cancel.sh) (in query: INSERT INTO data_b_01019 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:40.264177 [ 48599 ] {22} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:40.264390 [ 48599 ] {} TCPHandler: Code: 101. DB::NetException: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, char const (&) [44]) @ 0x00000000334c7456 4. ./build_docker/./src/Server/TCPHandler.cpp:2028: DB::TCPHandler::receiveUnexpectedData(bool) @ 0x00000000334bd3a1 5. ./build_docker/./src/Server/TCPHandler.cpp:1623: DB::TCPHandler::receivePacket() @ 0x000000003349bf98 6. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:40.397758 [ 48599 ] {11} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:42916) (comment: 01019_parallel_parsing_cancel.sh) (in query: INSERT INTO data_a_01019 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:40.397973 [ 48599 ] {11} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:40.398250 [ 48599 ] {} TCPHandler: Code: 101. DB::NetException: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, char const (&) [44]) @ 0x00000000334c7456 4. ./build_docker/./src/Server/TCPHandler.cpp:2028: DB::TCPHandler::receiveUnexpectedData(bool) @ 0x00000000334bd3a1 5. ./build_docker/./src/Server/TCPHandler.cpp:1623: DB::TCPHandler::receivePacket() @ 0x000000003349bf98 6. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:40.849209 [ 5338 ] {22} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:43004) (comment: 01019_parallel_parsing_cancel.sh) (in query: INSERT INTO data_b_01019 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:40.849431 [ 5338 ] {22} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:40.849624 [ 5338 ] {} TCPHandler: Code: 101. DB::NetException: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, char const (&) [44]) @ 0x00000000334c7456 4. ./build_docker/./src/Server/TCPHandler.cpp:2028: DB::TCPHandler::receiveUnexpectedData(bool) @ 0x00000000334bd3a1 5. ./build_docker/./src/Server/TCPHandler.cpp:1623: DB::TCPHandler::receivePacket() @ 0x000000003349bf98 6. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:41.898993 [ 23606 ] {22} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:43232) (comment: 01019_parallel_parsing_cancel.sh) (in query: INSERT INTO data_b_01019 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:41.899430 [ 23606 ] {22} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:41.899783 [ 23606 ] {} TCPHandler: Code: 101. DB::NetException: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, char const (&) [44]) @ 0x00000000334c7456 4. ./build_docker/./src/Server/TCPHandler.cpp:2028: DB::TCPHandler::receiveUnexpectedData(bool) @ 0x00000000334bd3a1 5. ./build_docker/./src/Server/TCPHandler.cpp:1623: DB::TCPHandler::receivePacket() @ 0x000000003349bf98 6. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:42.154493 [ 22860 ] {11} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:43296) (comment: 01019_parallel_parsing_cancel.sh) (in query: INSERT INTO data_a_01019 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:42.154737 [ 22860 ] {11} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:42.154930 [ 22860 ] {} TCPHandler: Code: 101. DB::NetException: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, char const (&) [44]) @ 0x00000000334c7456 4. ./build_docker/./src/Server/TCPHandler.cpp:2028: DB::TCPHandler::receiveUnexpectedData(bool) @ 0x00000000334bd3a1 5. ./build_docker/./src/Server/TCPHandler.cpp:1623: DB::TCPHandler::receivePacket() @ 0x000000003349bf98 6. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:42.532235 [ 5338 ] {22} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.3.12.76.altinitystable) (from [::1]:43362) (comment: 01019_parallel_parsing_cancel.sh) (in query: INSERT INTO data_b_01019 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:42.532549 [ 5338 ] {22} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000311a028e 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000033558b54 6. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000033558db9 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003355934a 8. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 9. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 12. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:42.532805 [ 5338 ] {} TCPHandler: Code: 101. DB::NetException: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, char const (&) [44]) @ 0x00000000334c7456 4. ./build_docker/./src/Server/TCPHandler.cpp:2028: DB::TCPHandler::receiveUnexpectedData(bool) @ 0x00000000334bd3a1 5. ./build_docker/./src/Server/TCPHandler.cpp:1623: DB::TCPHandler::receivePacket() @ 0x000000003349bf98 6. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:43.604220 [ 22860 ] {82c3f2b8-2b0c-4529-a9d7-0db605b51f82} executeQuery: Code: 206. DB::Exception: JOIN (SELECT 1 AS A, 2 AS B FROM system.one) AS X ALL LEFT JOIN (SELECT 3 AS A, 2 AS B FROM system.one) USING (B) no alias for subquery or table function SELECT 3 AS A, 2 AS B. In scope SELECT * FROM (SELECT 1 AS A, 2 AS B) AS X ALL LEFT JOIN (SELECT 3 AS A, 2 AS B) USING (B) (set joined_subquery_requires_alias = 0 to disable restriction). (ALIAS_REQUIRED) (version 24.3.12.76.altinitystable) (from [::1]:43580) (comment: 01000_subquery_requires_alias.sql) (in query: SELECT * FROM (SELECT 1 as A, 2 as B) X ALL LEFT JOIN (SELECT 3 as A, 2 as B) USING (B);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::validateJoinTableExpressionWithoutAlias(std::shared_ptr const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308e3a4e 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7734: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dc2e4 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:43.604521 [ 22860 ] {82c3f2b8-2b0c-4529-a9d7-0db605b51f82} TCPHandler: Code: 206. DB::Exception: JOIN (SELECT 1 AS A, 2 AS B FROM system.one) AS X ALL LEFT JOIN (SELECT 3 AS A, 2 AS B FROM system.one) USING (B) no alias for subquery or table function SELECT 3 AS A, 2 AS B. In scope SELECT * FROM (SELECT 1 AS A, 2 AS B) AS X ALL LEFT JOIN (SELECT 3 AS A, 2 AS B) USING (B) (set joined_subquery_requires_alias = 0 to disable restriction). (ALIAS_REQUIRED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::validateJoinTableExpressionWithoutAlias(std::shared_ptr const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308e3a4e 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7734: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dc2e4 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:43.627989 [ 22860 ] {c761e820-cfa2-4f2a-ad68-9977f58d2196} executeQuery: Code: 206. DB::Exception: JOIN (SELECT 1 AS A, 2 AS B FROM system.one) ALL LEFT JOIN (SELECT 3 AS A, 2 AS B FROM system.one) AS Y USING (B) no alias for subquery or table function SELECT 1 AS A, 2 AS B. In scope SELECT * FROM (SELECT 1 AS A, 2 AS B) ALL LEFT JOIN (SELECT 3 AS A, 2 AS B) AS Y USING (B) (set joined_subquery_requires_alias = 0 to disable restriction). (ALIAS_REQUIRED) (version 24.3.12.76.altinitystable) (from [::1]:43580) (comment: 01000_subquery_requires_alias.sql) (in query: SELECT * FROM (SELECT 1 as A, 2 as B) ALL LEFT JOIN (SELECT 3 as A, 2 as B) Y USING (B);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::validateJoinTableExpressionWithoutAlias(std::shared_ptr const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308e3a4e 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dc227 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:43.628242 [ 22860 ] {c761e820-cfa2-4f2a-ad68-9977f58d2196} TCPHandler: Code: 206. DB::Exception: JOIN (SELECT 1 AS A, 2 AS B FROM system.one) ALL LEFT JOIN (SELECT 3 AS A, 2 AS B FROM system.one) AS Y USING (B) no alias for subquery or table function SELECT 1 AS A, 2 AS B. In scope SELECT * FROM (SELECT 1 AS A, 2 AS B) ALL LEFT JOIN (SELECT 3 AS A, 2 AS B) AS Y USING (B) (set joined_subquery_requires_alias = 0 to disable restriction). (ALIAS_REQUIRED), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000181de9e3 4. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::validateJoinTableExpressionWithoutAlias(std::shared_ptr const&, std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308e3a4e 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x00000000308dc227 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x0000000030890765 7. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 8. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:43.843016 [ 5338 ] {3a9929e1-600a-4134-a719-1dde65ea3def} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_qqoomazm.constrained (6d226961-f28c-4f9d-8bee-5a8758546d4f) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:43656) (comment: 00998_constraints_all_tables.sql) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:43.843116 [ 5338 ] {3a9929e1-600a-4134-a719-1dde65ea3def} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_qqoomazm.constrained (6d226961-f28c-4f9d-8bee-5a8758546d4f) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:43.865038 [ 5338 ] {5b524d98-27fa-4c35-82cb-1de77fd1cd1a} executeQuery: Code: 469. DB::Exception: Constraint `is_utf8` for table test_qqoomazm.constrained (6d226961-f28c-4f9d-8bee-5a8758546d4f) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:43656) (comment: 00998_constraints_all_tables.sql) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:43.865155 [ 5338 ] {5b524d98-27fa-4c35-82cb-1de77fd1cd1a} TCPHandler: Code: 469. DB::Exception: Constraint `is_utf8` for table test_qqoomazm.constrained (6d226961-f28c-4f9d-8bee-5a8758546d4f) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:43.876267 [ 5338 ] {38cb072d-9fad-4e95-8948-7c113d044b8f} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_qqoomazm.constrained (7fd20e08-e234-482c-9877-b9c785656121) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:43656) (comment: 00998_constraints_all_tables.sql) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:43.876356 [ 5338 ] {38cb072d-9fad-4e95-8948-7c113d044b8f} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_qqoomazm.constrained (7fd20e08-e234-482c-9877-b9c785656121) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:43.882095 [ 5338 ] {73560a95-16c5-41d7-ba0c-4d541f16b4e9} executeQuery: Code: 469. DB::Exception: Constraint `is_utf8` for table test_qqoomazm.constrained (7fd20e08-e234-482c-9877-b9c785656121) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:43656) (comment: 00998_constraints_all_tables.sql) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:43.882224 [ 5338 ] {73560a95-16c5-41d7-ba0c-4d541f16b4e9} TCPHandler: Code: 469. DB::Exception: Constraint `is_utf8` for table test_qqoomazm.constrained (7fd20e08-e234-482c-9877-b9c785656121) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:43.955591 [ 5338 ] {b1d53a9d-cc28-4f45-8de8-82db4b2d6d0e} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_qqoomazm.constrained (ea7865c3-790a-4606-9b16-3356393836d5) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:43656) (comment: 00998_constraints_all_tables.sql) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:43.955744 [ 5338 ] {b1d53a9d-cc28-4f45-8de8-82db4b2d6d0e} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_qqoomazm.constrained (ea7865c3-790a-4606-9b16-3356393836d5) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:43.964172 [ 5338 ] {98f1d61b-c735-4198-9f58-7bf51327b41a} executeQuery: Code: 469. DB::Exception: Constraint `is_utf8` for table test_qqoomazm.constrained (ea7865c3-790a-4606-9b16-3356393836d5) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:43656) (comment: 00998_constraints_all_tables.sql) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:43.964297 [ 5338 ] {98f1d61b-c735-4198-9f58-7bf51327b41a} TCPHandler: Code: 469. DB::Exception: Constraint `is_utf8` for table test_qqoomazm.constrained (ea7865c3-790a-4606-9b16-3356393836d5) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:44.101629 [ 5338 ] {51b3304e-9b9a-4e73-8d8f-601cf8d33f88} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_qqoomazm.constrained (42868e19-fe66-41e4-a35c-12e50c91eeab) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:43656) (comment: 00998_constraints_all_tables.sql) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:44.101788 [ 5338 ] {51b3304e-9b9a-4e73-8d8f-601cf8d33f88} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_qqoomazm.constrained (42868e19-fe66-41e4-a35c-12e50c91eeab) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:44.109549 [ 5338 ] {3ecd576a-aaab-4e8a-bf49-748cccca05c9} executeQuery: Code: 469. DB::Exception: Constraint `is_utf8` for table test_qqoomazm.constrained (42868e19-fe66-41e4-a35c-12e50c91eeab) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:43656) (comment: 00998_constraints_all_tables.sql) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:44.109650 [ 5338 ] {3ecd576a-aaab-4e8a-bf49-748cccca05c9} TCPHandler: Code: 469. DB::Exception: Constraint `is_utf8` for table test_qqoomazm.constrained (42868e19-fe66-41e4-a35c-12e50c91eeab) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:44.233234 [ 5338 ] {a03baf12-ec94-4327-8459-5dba21cded3a} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_qqoomazm.constrained (c91c895b-0b68-4a7e-abf5-d5740f953d12) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:43656) (comment: 00998_constraints_all_tables.sql) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:44.233346 [ 5338 ] {a03baf12-ec94-4327-8459-5dba21cded3a} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_qqoomazm.constrained (c91c895b-0b68-4a7e-abf5-d5740f953d12) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:44.241412 [ 5338 ] {6e28db6a-63af-4698-ab68-31fd4c7726a4} executeQuery: Code: 469. DB::Exception: Constraint `is_utf8` for table test_qqoomazm.constrained (c91c895b-0b68-4a7e-abf5-d5740f953d12) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:43656) (comment: 00998_constraints_all_tables.sql) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:44.241549 [ 5338 ] {6e28db6a-63af-4698-ab68-31fd4c7726a4} TCPHandler: Code: 469. DB::Exception: Constraint `is_utf8` for table test_qqoomazm.constrained (c91c895b-0b68-4a7e-abf5-d5740f953d12) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:44.289047 [ 5338 ] {0bca4e41-90ee-4b18-92d5-851a6ca7cacd} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_qqoomazm.constrained (ba1924e9-6968-4ac1-959b-82b794bf62b2) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:43656) (comment: 00998_constraints_all_tables.sql) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:44.289174 [ 5338 ] {0bca4e41-90ee-4b18-92d5-851a6ca7cacd} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_qqoomazm.constrained (ba1924e9-6968-4ac1-959b-82b794bf62b2) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:44.300897 [ 5338 ] {e456b946-dfb5-4d2e-b442-70935e6633bb} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_qqoomazm.constrained2 (b6b72ab4-6aa1-4a9a-a2b0-f5256525ac64) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 24.3.12.76.altinitystable) (from [::1]:43656) (comment: 00998_constraints_all_tables.sql) (in query: INSERT INTO constrained2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:44.301013 [ 5338 ] {e456b946-dfb5-4d2e-b442-70935e6633bb} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_qqoomazm.constrained2 (b6b72ab4-6aa1-4a9a-a2b0-f5256525ac64) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f63b557 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000033b1ee45 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 10. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0faf 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:45.753622 [ 48631 ] {570f5226-2829-41a6-8a17-aecb9c9dfed0} executeQuery: Code: 475. DB::Exception: WITH FILL STEP value cannot be negative for sorting in ascending direction. (INVALID_WITH_FILL_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:44442) (comment: 00995_order_by_with_fill.sql) (in query: SELECT * FROM fill ORDER BY a WITH FILL STEP -1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerSorting.cpp:90: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x00000000310a2ddc 5. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100cc03 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:45.753791 [ 48631 ] {570f5226-2829-41a6-8a17-aecb9c9dfed0} TCPHandler: Code: 475. DB::Exception: WITH FILL STEP value cannot be negative for sorting in ascending direction. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerSorting.cpp:90: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x00000000310a2ddc 5. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100cc03 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:45.770720 [ 48631 ] {04e101e5-ec40-4ddd-a494-fdf803d11c7e} executeQuery: Code: 475. DB::Exception: WITH FILL TO value cannot be less than FROM value for sorting in ascending direction. (INVALID_WITH_FILL_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:44442) (comment: 00995_order_by_with_fill.sql) (in query: SELECT * FROM fill ORDER BY a WITH FILL FROM 10 TO 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerSorting.cpp:0: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x00000000310a2f5b 5. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100cc03 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:45.770889 [ 48631 ] {04e101e5-ec40-4ddd-a494-fdf803d11c7e} TCPHandler: Code: 475. DB::Exception: WITH FILL TO value cannot be less than FROM value for sorting in ascending direction. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerSorting.cpp:0: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x00000000310a2f5b 5. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100cc03 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:45.786637 [ 48631 ] {c6e047ae-846f-4f3d-bf0b-be061d1a8824} executeQuery: Code: 475. DB::Exception: WITH FILL FROM value cannot be less than TO value for sorting in descending direction. (INVALID_WITH_FILL_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:44442) (comment: 00995_order_by_with_fill.sql) (in query: SELECT * FROM fill ORDER BY a DESC WITH FILL FROM 1 TO 10;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerSorting.cpp:0: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x00000000310a2e6b 5. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100cc03 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:45.786898 [ 48631 ] {c6e047ae-846f-4f3d-bf0b-be061d1a8824} TCPHandler: Code: 475. DB::Exception: WITH FILL FROM value cannot be less than TO value for sorting in descending direction. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Planner/PlannerSorting.cpp:0: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x00000000310a2e6b 5. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100cc03 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:235: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000310009af 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc493 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 11. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 16. ? @ 0x00007fe1df9bbac3 17. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:45.810670 [ 48631 ] {847ec5dd-0bac-422c-83d0-36f8dccc8e2f} executeQuery: Code: 475. DB::Exception: WITH FILL bound values cannot be negative for unsigned type UInt32. (INVALID_WITH_FILL_EXPRESSION) (version 24.3.12.76.altinitystable) (from [::1]:44442) (comment: 00995_order_by_with_fill.sql) (in query: SELECT * FROM fill ORDER BY a WITH FILL FROM -10 to 10;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:0: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000033ebc346 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], bool const&>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9cac 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9a03 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000033eb8b8f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002f3e3b2e 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f3e38c1 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033eb7db8 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033edaab5 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:45.810899 [ 48631 ] {847ec5dd-0bac-422c-83d0-36f8dccc8e2f} TCPHandler: Code: 475. DB::Exception: WITH FILL bound values cannot be negative for unsigned type UInt32. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:0: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000033ebc346 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:296: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000], bool const&>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9cac 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:955: std::shared_ptr std::allocate_shared[abi:v15000], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x0000000033eb9a03 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000033eb8b8f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000002f3e3b2e 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f3e38c1 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033eb7db8 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033edaab5 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 18. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 23. ? @ 0x00007fe1df9bbac3 24. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:46.064552 [ 23498 ] {31bfd6ed-866a-4d72-aed4-5a94065c5209} executeQuery: Poco::Exception. Code: 1000, e.code() = 0, Bad URI syntax: URI contains invalid characters (version 24.3.12.76.altinitystable) (from [::1]:44674) (comment: 00990_request_splitting.sql) (in query: SELECT * FROM url('http://127.0.0.1:1337/? HTTP/1.1\r\nTest: test', CSV, 'column1 String');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:179: Poco::URISyntaxException::URISyntaxException(String const&, int) @ 0x000000003698d4e5 3. ./build_docker/./base/poco/Foundation/src/URI.cpp:0: Poco::URI::parse(String const&) @ 0x0000000036a3329a 4. ./build_docker/./base/poco/Foundation/src/URI.cpp:43: Poco::URI::URI(String const&, bool) @ 0x0000000036a32ee4 5. ./build_docker/./src/Storages/StorageURL.cpp:0: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000326566dd 6. ./build_docker/./src/Storages/StorageURL.cpp:1363: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000032666400 7. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageURL* std::construct_at[abi:v15000]&, String const&, std::vector> const&, String const&, DB::StorageURL*>(DB::StorageURL*, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e478eb9 8. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&, std::vector> const&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4788a4 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4785f4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e474635 11. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:16:46.064805 [ 23498 ] {31bfd6ed-866a-4d72-aed4-5a94065c5209} TCPHandler: Code: 1000. DB::Exception: Bad URI syntax: URI contains invalid characters. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./base/poco/Foundation/src/Exception.cpp:179: Poco::URISyntaxException::URISyntaxException(String const&, int) @ 0x000000003698d4e5 3. ./build_docker/./base/poco/Foundation/src/URI.cpp:0: Poco::URI::parse(String const&) @ 0x0000000036a3329a 4. ./build_docker/./base/poco/Foundation/src/URI.cpp:43: Poco::URI::URI(String const&, bool) @ 0x0000000036a32ee4 5. ./build_docker/./src/Storages/StorageURL.cpp:0: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000326566dd 6. ./build_docker/./src/Storages/StorageURL.cpp:1363: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000032666400 7. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageURL* std::construct_at[abi:v15000]&, String const&, std::vector> const&, String const&, DB::StorageURL*>(DB::StorageURL*, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e478eb9 8. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000]&, String const&, std::vector> const&, String const&>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4788a4 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, void>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&) @ 0x000000002e4785f4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000002e474635 11. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:133: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002e46beba 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:37: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002e8e153e 13. ./build_docker/./src/Interpreters/Context.cpp:2014: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002fc62380 14. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:7558: DB::(anonymous namespace)::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&, bool) @ 0x000000003088bcec 15. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, DB::(anonymous namespace)::QueryExpressionsAliasVisitor&) @ 0x000000003088fd6c 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:8164: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e8c5 17. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 22. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 27. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 2025.03.05 21:16:46.388736 [ 23562 ] {b4850180-84bf-4856-ac00-4bbc21987b83} executeQuery: Code: 36. DB::Exception: Needle must not contain whitespace or separator characters: while executing 'FUNCTION hasToken(__table1.s :: 2, 'abc,def,zzz'_String :: 1) -> hasToken(__table1.s, 'abc,def,zzz'_String) UInt8 : 3': While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44808) (comment: 00990_hasToken_and_tokenbf.sql) (in query: SELECT max(id) FROM bloom_filter WHERE hasToken(s, 'abc,def,zzz');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::HasTokenImpl>, false>::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001cd97145 5. DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd94352 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 12. ./contrib/llvm-project/libcxx/include/vector:537: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002fdbd37f 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000032dfa2fc 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1067: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df64b3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df4a7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:164: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000032e04f6f 17. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000033f8b134 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:139: DB::MergeTreeSelectProcessor::read() @ 0x0000000032de396f 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:0: DB::MergeTreeSource::tryGenerate() @ 0x0000000033fb1d35 20. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:46.409481 [ 23498 ] {80fe1441-7aae-4910-9e46-13300a52e2ae} executeQuery: Code: 36. DB::Exception: Query tree is too big. Maximum: 500000. (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44854) (comment: 00988_expansion_aliases_limit.sql) (in query: SELECT 1 AS a, a + a AS b, b + b AS c, c + c AS d, d + d AS e, e + e AS f, f + f AS g, g + g AS h, h + h AS i, i + i AS j, j + j AS k, k + k AS l, l + l AS m, m + m AS n, n + n AS o, o + o AS p, p + p AS q, q + q AS r, r + r AS s, s + s AS t, t + t AS u, u + u AS v, v + v AS w, w + w AS x, x + x AS y, y + y AS z;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000001904abbb 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:391: DB::validateTreeSize(std::shared_ptr const&, unsigned long, std::unordered_map, unsigned long, std::hash>, std::equal_to>, std::allocator const, unsigned long>>>&) @ 0x000000003093fcc9 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883072 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:46.409583 [ 23562 ] {b4850180-84bf-4856-ac00-4bbc21987b83} TCPHandler: Code: 36. DB::Exception: Needle must not contain whitespace or separator characters: while executing 'FUNCTION hasToken(__table1.s :: 2, 'abc,def,zzz'_String :: 1) -> hasToken(__table1.s, 'abc,def,zzz'_String) UInt8 : 3': While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::HasTokenImpl>, false>::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001cd97145 5. DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd94352 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 12. ./contrib/llvm-project/libcxx/include/vector:537: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002fdbd37f 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000032dfa2fc 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1067: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df64b3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df4a7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:164: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000032e04f6f 17. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000033f8b134 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:139: DB::MergeTreeSelectProcessor::read() @ 0x0000000032de396f 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:0: DB::MergeTreeSource::tryGenerate() @ 0x0000000033fb1d35 20. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:46.409807 [ 23498 ] {80fe1441-7aae-4910-9e46-13300a52e2ae} TCPHandler: Code: 36. DB::Exception: Query tree is too big. Maximum: 500000. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000001904abbb 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:391: DB::validateTreeSize(std::shared_ptr const&, unsigned long, std::unordered_map, unsigned long, std::hash>, std::equal_to>, std::allocator const, unsigned long>>>&) @ 0x000000003093fcc9 5. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:0: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030883072 6. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 8. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 9. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 14. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 19. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 24. ? @ 0x00007fe1df9bbac3 25. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:46.440853 [ 23562 ] {ac6ce75e-822d-4474-8e94-c7d037ddd2da} executeQuery: Code: 36. DB::Exception: Needle must not contain whitespace or separator characters: while executing 'FUNCTION hasTokenCaseInsensitive(__table1.s :: 2, 'abc,def,zzz'_String :: 1) -> hasTokenCaseInsensitive(__table1.s, 'abc,def,zzz'_String) UInt8 : 3': While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:44808) (comment: 00990_hasToken_and_tokenbf.sql) (in query: SELECT max(id) FROM bloom_filter WHERE hasTokenCaseInsensitive(s, 'abc,def,zzz');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::HasTokenImpl>, false>::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001cda0205 5. DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd9d412 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 12. ./contrib/llvm-project/libcxx/include/vector:537: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002fdbd37f 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000032dfa2fc 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1067: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df64b3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df4a7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:164: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000032e04f6f 17. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000033f8b134 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:139: DB::MergeTreeSelectProcessor::read() @ 0x0000000032de396f 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:0: DB::MergeTreeSource::tryGenerate() @ 0x0000000033fb1d35 20. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:46.441289 [ 23562 ] {ac6ce75e-822d-4474-8e94-c7d037ddd2da} TCPHandler: Code: 36. DB::Exception: Needle must not contain whitespace or separator characters: while executing 'FUNCTION hasTokenCaseInsensitive(__table1.s :: 2, 'abc,def,zzz'_String :: 1) -> hasTokenCaseInsensitive(__table1.s, 'abc,def,zzz'_String) UInt8 : 3': While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. DB::HasTokenImpl>, false>::vectorConstant(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, String const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*) @ 0x000000001cda0205 5. DB::FunctionsStringSearch>, false>, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cd9d412 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 12. ./contrib/llvm-project/libcxx/include/vector:537: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002fdbd37f 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x0000000032dfa2fc 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1067: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df64b3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000032df4a7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:164: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000032e04f6f 17. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000033f8b134 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:139: DB::MergeTreeSelectProcessor::read() @ 0x0000000032de396f 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:0: DB::MergeTreeSource::tryGenerate() @ 0x0000000033fb1d35 20. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003353f397 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000003355aebb 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003355ba65 24. ./build_docker/./src/Common/ThreadPool.cpp:532: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000247849cf 25. ./build_docker/./src/Common/ThreadPool.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x000000002478ab74 26. ./base/base/../base/wide_integer_impl.h:810: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000247807f8 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x0000000024786eea 28. ? @ 0x00007fe1df9bbac3 29. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:46.599887 [ 23562 ] {be524bbe-b57a-4043-884d-470379b6a02b} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 16.00, current rows: 2.05 thousand. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:44808) (comment: 00990_hasToken_and_tokenbf.sql) (in query: -- invert result -- this does not work as expected, reading more rows that it should -- SELECT max(id) FROM bloom_filter WHERE NOT hasToken(s, 'yyy'); -- accessing to many rows SELECT max(id) FROM bloom_filter WHERE hasToken(s, 'yyy');), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:257: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f496ac 6. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:46.600012 [ 23562 ] {be524bbe-b57a-4043-884d-470379b6a02b} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 16.00, current rows: 2.05 thousand. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:257: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f496ac 6. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:46.603230 [ 23562 ] {bb27a4eb-6ccb-4a09-8168-5c4e3290b7a4} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 16.00, current rows: 3.08 thousand. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:44808) (comment: 00990_hasToken_and_tokenbf.sql) (in query: -- this syntax is not supported by tokenbf SELECT max(id) FROM bloom_filter WHERE hasToken(s, 'zzz') == 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:257: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f496ac 6. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:46.603343 [ 23562 ] {bb27a4eb-6ccb-4a09-8168-5c4e3290b7a4} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 16.00, current rows: 3.08 thousand. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f44fa71 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f44f7c9 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:257: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f496ac 6. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000033ed9de5 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000033f103fd 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000003100077e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000003100021c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:46.709104 [ 81460 ] {f984bdeb-d8a8-48e3-8230-467cd8b83bd8} executeQuery: Code: 269. DB::Exception: Distributed table distr looks at itself. (INFINITE_LOOP) (version 24.3.12.76.altinitystable) (from [::1]:44978) (comment: 00987_distributed_stack_overflow.sql) (in query: CREATE TABLE distr (x UInt8) ENGINE = Distributed(test_shard_localhost, currentDatabase(), distr);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:382: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr) @ 0x000000003218ad24 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageDistributed* std::construct_at[abi:v15000] const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&, DB::StorageDistributed*>(DB::StorageDistributed*, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x00000000321c8997 6. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000] const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&>(std::allocator, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x00000000321c86cd 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x00000000321c841a 8. ./build_docker/./src/Storages/StorageDistributed.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000321bbed3 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:46.709400 [ 81460 ] {f984bdeb-d8a8-48e3-8230-467cd8b83bd8} TCPHandler: Code: 269. DB::Exception: Distributed table distr looks at itself. (INFINITE_LOOP), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:382: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr) @ 0x000000003218ad24 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageDistributed* std::construct_at[abi:v15000] const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&, DB::StorageDistributed*>(DB::StorageDistributed*, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x00000000321c8997 6. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000] const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&>(std::allocator, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x00000000321c86cd 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x00000000321c841a 8. ./build_docker/./src/Storages/StorageDistributed.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000321bbed3 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:46.711777 [ 81460 ] {ceca508a-a9f2-4906-9658-7e90ea3ec7c4} StorageDistributed (distr0): Name of remote database is empty. Default database will be used implicitly. 2025.03.05 21:16:46.712106 [ 81460 ] {ceca508a-a9f2-4906-9658-7e90ea3ec7c4} executeQuery: Code: 269. DB::Exception: Distributed table distr0 looks at itself. (INFINITE_LOOP) (version 24.3.12.76.altinitystable) (from [::1]:44978) (comment: 00987_distributed_stack_overflow.sql) (in query: CREATE TABLE distr0 (x UInt8) ENGINE = Distributed(test_shard_localhost, '', distr0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:382: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr) @ 0x000000003218ad24 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageDistributed* std::construct_at[abi:v15000] const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&, DB::StorageDistributed*>(DB::StorageDistributed*, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x00000000321c8997 6. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000] const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&>(std::allocator, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x00000000321c86cd 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x00000000321c841a 8. ./build_docker/./src/Storages/StorageDistributed.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000321bbed3 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:46.712268 [ 81460 ] {ceca508a-a9f2-4906-9658-7e90ea3ec7c4} TCPHandler: Code: 269. DB::Exception: Distributed table distr0 looks at itself. (INFINITE_LOOP), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018092ceb 4. ./build_docker/./src/Storages/StorageDistributed.cpp:382: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr) @ 0x000000003218ad24 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageDistributed* std::construct_at[abi:v15000] const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&, DB::StorageDistributed*>(DB::StorageDistributed*, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x00000000321c8997 6. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15000] const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&>(std::allocator, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x00000000321c86cd 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:953: std::shared_ptr std::allocate_shared[abi:v15000], DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x00000000321c841a 8. ./build_docker/./src/Storages/StorageDistributed.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000321bbed3 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 16. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 21. ? @ 0x00007fe1df9bbac3 22. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:46.728889 [ 81460 ] {7e0c1777-b5f7-4fae-9273-82de70762e49} executeQuery: Code: 581. DB::Exception: Maximum distributed depth exceeded. (TOO_LARGE_DISTRIBUTED_DEPTH) (version 24.3.12.76.altinitystable) (from [::1]:44978) (comment: 00987_distributed_stack_overflow.sql) (in query: SELECT * FROM distr1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:217: DB::ClusterProxy::executeQuery(DB::QueryPlan&, DB::Block const&, DB::QueryProcessingStage::Enum, DB::StorageID const&, std::shared_ptr const&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr, std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, String const&, DB::DistributedSettings const&, std::function (unsigned long)>) @ 0x00000000318f0a11 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 11. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:76: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb48c1 12. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 13. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 19. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 22. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:76: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb48c1 23. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 24. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 28. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 29. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 30. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 2025.03.05 21:16:46.729060 [ 81460 ] {7e0c1777-b5f7-4fae-9273-82de70762e49} TCPHandler: Code: 581. DB::Exception: Maximum distributed depth exceeded. (TOO_LARGE_DISTRIBUTED_DEPTH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:217: DB::ClusterProxy::executeQuery(DB::QueryPlan&, DB::Block const&, DB::QueryProcessingStage::Enum, DB::StorageID const&, std::shared_ptr const&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr, std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, String const&, DB::DistributedSettings const&, std::function (unsigned long)>) @ 0x00000000318f0a11 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 11. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:76: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb48c1 12. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 13. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 19. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 22. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:76: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb48c1 23. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 24. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 28. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 29. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 30. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 2025.03.05 21:16:46.735864 [ 81460 ] {4b1025f0-396b-49af-853c-11243d0d263d} executeQuery: Code: 581. DB::Exception: Maximum distributed depth exceeded. (TOO_LARGE_DISTRIBUTED_DEPTH) (version 24.3.12.76.altinitystable) (from [::1]:44978) (comment: 00987_distributed_stack_overflow.sql) (in query: SELECT * FROM distr2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:217: DB::ClusterProxy::executeQuery(DB::QueryPlan&, DB::Block const&, DB::QueryProcessingStage::Enum, DB::StorageID const&, std::shared_ptr const&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr, std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, String const&, DB::DistributedSettings const&, std::function (unsigned long)>) @ 0x00000000318f0a11 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 11. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:76: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb48c1 12. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 13. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 19. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 22. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:76: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb48c1 23. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 24. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 28. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 29. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 30. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 2025.03.05 21:16:46.736055 [ 81460 ] {4b1025f0-396b-49af-853c-11243d0d263d} TCPHandler: Code: 581. DB::Exception: Maximum distributed depth exceeded. (TOO_LARGE_DISTRIBUTED_DEPTH), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:217: DB::ClusterProxy::executeQuery(DB::QueryPlan&, DB::Block const&, DB::QueryProcessingStage::Enum, DB::StorageID const&, std::shared_ptr const&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr, std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, String const&, DB::DistributedSettings const&, std::function (unsigned long)>) @ 0x00000000318f0a11 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 11. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:76: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb48c1 12. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 13. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 19. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000031000aaf 22. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:76: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000033eb48c1 23. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:160: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000318e94f6 24. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:233: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000318e75f5 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318e9851 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000318effc6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000321982b8 28. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000003105fc07 29. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1673: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000003104d9e0 30. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000003100b92b 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000031005064 2025.03.05 21:16:47.274011 [ 81460 ] {3a8193b5-1d75-469b-a83b-a9b114a13056} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(x, 1500000) :: 4) -> throwIf(equals(x, 1500000)) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.3.12.76.altinitystable) (from [::1]:45080) (comment: 00995_exception_while_insert.sh) (in query: INSERT INTO check(x) FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000033b53941 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 19. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 20. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:47.274174 [ 81460 ] {3a8193b5-1d75-469b-a83b-a9b114a13056} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(x, 1500000) :: 4) -> throwIf(equals(x, 1500000)) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000219c9d8d 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000187897c1 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f7c8 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 8. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002fdbc669 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:0: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002fdb9fea 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ConvertingTransform::onConsume(DB::Chunk) @ 0x0000000033b53941 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000033b52ad4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000033b5265e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000033b513ef 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:50: DB::ExecutionThreadContext::executeTask() @ 0x000000003356c770 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000033559afb 17. ./contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000033559203 18. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x0000000033579fa8 19. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000003357a0fc 20. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x00000000334a0a27 21. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x00000000334871d2 22. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 26. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 27. ? @ 0x00007fe1df9bbac3 28. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:47.279006 [ 81460 ] {} TCPHandler: Code: 101. DB::NetException: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, char const (&) [44]) @ 0x00000000334c7456 4. ./build_docker/./src/Server/TCPHandler.cpp:2028: DB::TCPHandler::receiveUnexpectedData(bool) @ 0x00000000334bd3a1 5. ./build_docker/./src/Server/TCPHandler.cpp:1623: DB::TCPHandler::receivePacket() @ 0x000000003349bf98 6. ./build_docker/./src/Server/TCPHandler.cpp:372: DB::TCPHandler::runImpl() @ 0x0000000033485532 7. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 12. ? @ 0x00007fe1df9bbac3 13. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:47.374495 [ 23635 ] {91c120b1-e23f-4cf9-9e65-f80e7c6fbe39} executeQuery: Code: 223. DB::Exception: [price, spend] is not an identifier. (UNEXPECTED_AST_STRUCTURE) (version 24.3.12.76.altinitystable) (from [::1]:45300) (comment: 00983_summing_merge_tree_not_an_identifier.sql) (in query: CREATE TABLE xx (`date` Date, `id` Int64, `clicks` Int64, `price` Float64, `spend` Float64) ENGINE = SummingMergeTree([price, spend]) PARTITION BY toYYYYMM(date) ORDER BY id SAMPLE BY id SETTINGS index_granularity = 8192, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 481461055, compact_parts_max_granules_to_buffer = 129, compact_parts_merge_max_bytes_to_prefetch_part = 7131375, merge_max_block_size = 18836, old_parts_lifetime = 114., prefer_fetch_merged_part_size_threshold = 6416451612, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 43, min_merge_bytes_to_use_direct_io = 10391189470, index_granularity_bytes = 6747209, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 76462, primary_key_compress_block_size = 64962), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Parsers/ASTIdentifier.cpp:0: DB::getIdentifierName(DB::IAST const*) @ 0x0000000034509450 5. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306dcf1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:47.374689 [ 23635 ] {91c120b1-e23f-4cf9-9e65-f80e7c6fbe39} TCPHandler: Code: 223. DB::Exception: [price, spend] is not an identifier. (UNEXPECTED_AST_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000001805d8ab 4. ./build_docker/./src/Parsers/ASTIdentifier.cpp:0: DB::getIdentifierName(DB::IAST const*) @ 0x0000000034509450 5. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003306dcf1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000321d57e0 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&) @ 0x00000000307cb46b 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000307c1ea4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1794: DB::InterpreterCreateQuery::execute() @ 0x00000000307d5674 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fcebe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 13. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 18. ? @ 0x00007fe1df9bbac3 19. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:48.568622 [ 48602 ] {8438a256-4377-4d4f-a3a5-fd5978ac8b7e} executeQuery: Code: 306. DB::Exception: Maximum parse depth (1000) exceeded. Consider rising max_parser_depth parameter. (TOO_DEEP_RECURSION) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:53494) (comment: 00984_parser_stack_overflow.sh) (in query: ((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x000000002e97541a 4. ./src/Parsers/IParserBase.h:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462545e 5. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f57f5 6. ./src/Parsers/ExpressionListParsers.h:0: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e4ea7 7. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 8. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346a9d9d 9. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 10. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:0: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345b4b4e 11. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 12. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346dd2a8 13. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 14. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f57f5 15. ./src/Parsers/ExpressionListParsers.h:0: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e4ea7 16. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 17. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346a9d9d 18. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 19. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:0: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345b4b4e 20. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 21. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346dd2a8 22. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 23. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f57f5 24. ./src/Parsers/ExpressionListParsers.h:0: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e4ea7 25. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 26. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346a9d9d 27. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 28. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:0: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345b4b4e 29. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 30. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346dd2a8 31. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 2025.03.05 21:16:48.569015 [ 48602 ] {8438a256-4377-4d4f-a3a5-fd5978ac8b7e} DynamicQueryHandler: Code: 306. DB::Exception: Maximum parse depth (1000) exceeded. Consider rising max_parser_depth parameter. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x000000002e97541a 4. ./src/Parsers/IParserBase.h:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462545e 5. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f57f5 6. ./src/Parsers/ExpressionListParsers.h:0: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e4ea7 7. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 8. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346a9d9d 9. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 10. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:0: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345b4b4e 11. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 12. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346dd2a8 13. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 14. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f57f5 15. ./src/Parsers/ExpressionListParsers.h:0: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e4ea7 16. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 17. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346a9d9d 18. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 19. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:0: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345b4b4e 20. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 21. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346dd2a8 22. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 23. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f57f5 24. ./src/Parsers/ExpressionListParsers.h:0: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e4ea7 25. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 26. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346a9d9d 27. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 28. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:0: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345b4b4e 29. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 30. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346dd2a8 31. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c (version 24.3.12.76.altinitystable) 2025.03.05 21:16:48.618172 [ 48602 ] {71d2069a-b857-4d04-b9e7-35b75092aa9b} executeQuery: Code: 306. DB::Exception: Maximum parse depth (1000) exceeded. Consider rising max_parser_depth parameter. (TOO_DEEP_RECURSION) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:53508) (comment: 00984_parser_stack_overflow.sh) (in query: SELECT [[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x000000002e97541a 4. ./src/Parsers/IParserBase.h:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462545e 5. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:859: DB::ParserNull::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345c0bcc 6. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 7. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:0: DB::ParserLiteral::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345c5c80 8. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 9. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:1241: DB::ParserCollectionOfLiterals::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345d8e01 10. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 11. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 12. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:2622: DB::ParserExpressionImpl::tryParseOperand(std::vector>, std::allocator>>>&, DB::IParser::Pos&, DB::Expected&) @ 0x00000000345ee1cc 13. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:0: DB::ParserExpressionImpl::parse(std::unique_ptr>, DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345eb465 14. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:2343: DB::ParserExpression::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345eaf10 15. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 16. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:2005: DB::ParserWithOptionalAlias::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345d033e 17. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 18. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 19. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 20. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 21. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 22. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:0: DB::ParserExpressionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e74ff 23. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 24. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:327: DB::ParserNotEmptyExpressionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e7708 25. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 26. ./build_docker/./src/Parsers/ParserSelectQuery.cpp:0: DB::ParserSelectQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346de653 27. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 28. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346dd320 29. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 30. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f57f5 31. ./src/Parsers/ExpressionListParsers.h:0: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e4ea7 2025.03.05 21:16:48.618462 [ 48602 ] {71d2069a-b857-4d04-b9e7-35b75092aa9b} DynamicQueryHandler: Code: 306. DB::Exception: Maximum parse depth (1000) exceeded. Consider rising max_parser_depth parameter. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x000000002e97541a 4. ./src/Parsers/IParserBase.h:0: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462545e 5. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:859: DB::ParserNull::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345c0bcc 6. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 7. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:0: DB::ParserLiteral::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345c5c80 8. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 9. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:1241: DB::ParserCollectionOfLiterals::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345d8e01 10. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 11. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 12. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:2622: DB::ParserExpressionImpl::tryParseOperand(std::vector>, std::allocator>>>&, DB::IParser::Pos&, DB::Expected&) @ 0x00000000345ee1cc 13. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:0: DB::ParserExpressionImpl::parse(std::unique_ptr>, DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345eb465 14. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:2343: DB::ParserExpression::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345eaf10 15. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 16. ./build_docker/./src/Parsers/ExpressionElementParsers.cpp:2005: DB::ParserWithOptionalAlias::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345d033e 17. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 18. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 19. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f55c1 20. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:60: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e499c 21. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 22. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:0: DB::ParserExpressionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e74ff 23. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 24. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:327: DB::ParserNotEmptyExpressionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e7708 25. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 26. ./build_docker/./src/Parsers/ParserSelectQuery.cpp:0: DB::ParserSelectQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346de653 27. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 28. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000346dd320 29. ./build_docker/./src/Parsers/IParserBase.cpp:13: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003462528c 30. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x00000000345f57f5 31. ./src/Parsers/ExpressionListParsers.h:0: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x00000000345e4ea7 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:48.699641 [ 81473 ] {66094376-c3e5-4c11-9efa-43c562c01895} executeQuery: Code: 36. DB::Exception: The value of the second argument of function kostikConsistentHash (number of buckets) must not be greater than 32768: In scope SELECT kostikConsistentHash(-1, 40000). (BAD_ARGUMENTS) (version 24.3.12.76.altinitystable) (from [::1]:45982) (comment: 00979_yandex_consistent_hash_fpe.sql) (in query: SELECT kostikConsistentHash(-1, 40000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int const&) @ 0x000000001cd59192 4. unsigned short DB::FunctionConsistentHashImpl::checkBucketsRange(unsigned long) const @ 0x000000001d826387 5. DB::FunctionConsistentHashImpl::executeConstBuckets(std::vector> const&) const @ 0x000000001d825584 6. DB::FunctionConsistentHashImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d8249c5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:16:48.699836 [ 81473 ] {66094376-c3e5-4c11-9efa-43c562c01895} TCPHandler: Code: 36. DB::Exception: The value of the second argument of function kostikConsistentHash (number of buckets) must not be greater than 32768: In scope SELECT kostikConsistentHash(-1, 40000). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int const&) @ 0x000000001cd59192 4. unsigned short DB::FunctionConsistentHashImpl::checkBucketsRange(unsigned long) const @ 0x000000001d826387 5. DB::FunctionConsistentHashImpl::executeConstBuckets(std::vector> const&) const @ 0x000000001d825584 6. DB::FunctionConsistentHashImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d8249c5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 9. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83edb2 11. ./contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f656 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 13. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 15. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 16. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 18. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 24. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 29. ./build_docker/./src/Server/TCPHandler.cpp:2341: DB::TCPHandler::run() @ 0x00000000334c15d6 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 2025.03.05 21:16:49.281481 [ 48602 ] {2e62d66d-fbc9-4ce0-ac8c-26b458e0d7af} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 8 ('('): ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([. Unmatched parentheses: ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([. (SYNTAX_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:53522) (comment: 00984_parser_stack_overflow.sh) (in query: SELECT ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:49.281758 [ 48602 ] {2e62d66d-fbc9-4ce0-ac8c-26b458e0d7af} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 8 ('('): ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([. Unmatched parentheses: ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000024705483 4. ./build_docker/./src/Parsers/parseQuery.cpp:373: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc2f5 5. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 9. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 15. ? @ 0x00007fe1df9bbac3 16. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:49.369073 [ 48602 ] {c89f84b5-8ee7-44b1-b66f-1b964d5e7994} executeQuery: Code: 167. DB::Exception: AST is too deep. Maximum: 1000. (TOO_DEEP_AST) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:52658) (comment: 00984_parser_stack_overflow.sh) (in query: SELECT 1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000001904abbb 4. ./build_docker/./src/Parsers/IAST.cpp:157: DB::IAST::checkDepthImpl(unsigned long) const @ 0x00000000346226c1 5. ./build_docker/./src/Parsers/parseQuery.cpp:274: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000346f9fa2 6. ./build_docker/./src/Parsers/parseQuery.cpp:366: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc28e 7. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 2025.03.05 21:16:49.369562 [ 48602 ] {c89f84b5-8ee7-44b1-b66f-1b964d5e7994} DynamicQueryHandler: Code: 167. DB::Exception: AST is too deep. Maximum: 1000. (TOO_DEEP_AST), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000001904abbb 4. ./build_docker/./src/Parsers/IAST.cpp:157: DB::IAST::checkDepthImpl(unsigned long) const @ 0x00000000346226c1 5. ./build_docker/./src/Parsers/parseQuery.cpp:274: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000346f9fa2 6. ./build_docker/./src/Parsers/parseQuery.cpp:366: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc28e 7. ./build_docker/./src/Parsers/parseQuery.cpp:386: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000346fc38d 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316f5f71 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function) @ 0x0000000031702b3c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000333d27a5 11. ./build_docker/./src/Server/HTTPHandler.cpp:1091: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000333d91ef 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000334d5432 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000367bfcde 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000367c0dfa 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:202: Poco::PooledThread::run() @ 0x0000000036a2cc70 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000036a27d71 17. ? @ 0x00007fe1df9bbac3 18. ? @ 0x00007fe1dfa4d850 (version 24.3.12.76.altinitystable) 2025.03.05 21:16:49.434093 [ 23606 ] {a73279e5-7f0a-4ba2-a82a-919cc0425203} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT intDiv(-1, 0). (ILLEGAL_DIVISION) (version 24.3.12.76.altinitystable) (from [::1]:56224) (comment: 00977_int_div.sql) (in query: SELECT -1 DIV 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::throwIfDivisionLeadsToFPE(signed char, signed char) @ 0x000000001cf0a636 5. COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d2e073c 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001d2e0122 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d2df15f 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d251fe1 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d24d3ac 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d24a585 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d2484b1 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:16:49.434304 [ 23606 ] {a73279e5-7f0a-4ba2-a82a-919cc0425203} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT intDiv(-1, 0). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. std::exception::capture() @ 0x00000000181df475 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:28: Poco::Exception::Exception(String const&, int) @ 0x000000003697a885 2. ./build_docker/./src/Common/Exception.cpp:96: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002467412b 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000001807634e 4. void DB::throwIfDivisionLeadsToFPE(signed char, signed char) @ 0x000000001cf0a636 5. COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d2e073c 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001d2e0122 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d2df15f 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001d251fe1 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001d24d3ac 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d24a585 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d2484b1 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001805cc9f 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018789941 14. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e83f759 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e840a32 16. ./build_docker/./src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002e842957 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x00000000308b26f0 18. ./contrib/llvm-project/libcxx/include/vector:543: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030882984 19. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:6642: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x0000000030881521 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003089258c 21. ./contrib/llvm-project/libcxx/include/vector:951: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000003086e98a 22. ./build_docker/./src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000003086afbd 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000030863b06 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000030fff3f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000030ffc503 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000031001d58 27. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:40: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000031000f68 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030f21ec3 29. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000316fc079 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000316f5567 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000033486d86 2025.03.05 21:16:55.132522 [ 726 ] {} Application: Child process was terminated by signal 9 (KILL). If it is not done by 'forcestop' command or manually, the possible cause is OOM Killer (see 'dmesg' and look at the '/var/log/kern.log' for the details).